Package | Description |
---|---|
org.apache.hadoop.yarn.server.api.protocolrecords | |
org.apache.hadoop.yarn.server.api.protocolrecords.impl.pb | |
org.apache.hadoop.yarn.server.scheduler |
Utility classes used for Scheduling.
|
Modifier and Type | Method and Description |
---|---|
static RemoteNode |
RemoteNode.newInstance(org.apache.hadoop.yarn.api.records.NodeId nodeId,
String httpAddress)
Create new Instance.
|
static RemoteNode |
RemoteNode.newInstance(org.apache.hadoop.yarn.api.records.NodeId nodeId,
String httpAddress,
String rackName)
Create new Instance.
|
static RemoteNode |
RemoteNode.newInstance(org.apache.hadoop.yarn.api.records.NodeId nodeId,
String httpAddress,
String rackName,
String nodePartition)
Create new Instance.
|
Modifier and Type | Method and Description |
---|---|
abstract List<RemoteNode> |
RegisterDistributedSchedulingAMResponse.getNodesForScheduling() |
abstract List<RemoteNode> |
DistributedSchedulingAllocateResponse.getNodesForScheduling() |
Modifier and Type | Method and Description |
---|---|
int |
RemoteNode.compareTo(RemoteNode other) |
Modifier and Type | Method and Description |
---|---|
abstract void |
RegisterDistributedSchedulingAMResponse.setNodesForScheduling(List<RemoteNode> nodesForScheduling) |
abstract void |
DistributedSchedulingAllocateResponse.setNodesForScheduling(List<RemoteNode> nodesForScheduling) |
Modifier and Type | Class and Description |
---|---|
class |
RemoteNodePBImpl
Implementation of
RemoteNode . |
Modifier and Type | Method and Description |
---|---|
List<RemoteNode> |
DistributedSchedulingAllocateResponsePBImpl.getNodesForScheduling() |
List<RemoteNode> |
RegisterDistributedSchedulingAMResponsePBImpl.getNodesForScheduling() |
Modifier and Type | Method and Description |
---|---|
void |
DistributedSchedulingAllocateResponsePBImpl.setNodesForScheduling(List<RemoteNode> nodesForScheduling) |
void |
RegisterDistributedSchedulingAMResponsePBImpl.setNodesForScheduling(List<RemoteNode> nodesForScheduling) |
Modifier and Type | Method and Description |
---|---|
Map<String,RemoteNode> |
OpportunisticContainerContext.getNodeMap() |
Modifier and Type | Method and Description |
---|---|
protected org.apache.hadoop.yarn.api.records.Container |
OpportunisticContainerAllocator.createContainer(long rmIdentifier,
OpportunisticContainerAllocator.AllocationParams appParams,
OpportunisticContainerAllocator.ContainerIdGenerator idCounter,
org.apache.hadoop.yarn.api.records.ApplicationAttemptId id,
String userName,
Map<org.apache.hadoop.yarn.api.records.Resource,List<OpportunisticContainerAllocator.Allocation>> allocations,
String location,
org.apache.hadoop.yarn.api.records.ResourceRequest anyAsk,
RemoteNode rNode) |
protected String |
OpportunisticContainerAllocator.getRemoteNodePartition(RemoteNode node) |
Modifier and Type | Method and Description |
---|---|
void |
OpportunisticContainerContext.updateNodeList(List<RemoteNode> newNodeList) |
Copyright © 2008–2020 Apache Software Foundation. All rights reserved.