Modifier and Type | Method and Description |
---|---|
RMNode |
NodesListManagerEvent.getNode() |
Modifier and Type | Method and Description |
---|---|
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMContext.getInactiveRMNodes() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMContextImpl.getInactiveRMNodes() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMActiveServiceContext.getInactiveRMNodes() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMContext.getRMNodes() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMContextImpl.getRMNodes() |
ConcurrentMap<org.apache.hadoop.yarn.api.records.NodeId,RMNode> |
RMActiveServiceContext.getRMNodes() |
static List<RMNode> |
RMServerUtils.queryRMNodes(RMContext context,
EnumSet<org.apache.hadoop.yarn.api.records.NodeState> acceptedStates) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterMonitor.addNode(List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerStatuses,
RMNode rmNode) |
void |
ClusterMonitor.removeNode(RMNode removedRMNode) |
void |
DecommissioningNodesWatcher.update(RMNode rmNode,
org.apache.hadoop.yarn.server.api.records.NodeStatus remoteNodeStatus)
Update rmNode decommissioning status based on NodeStatus.
|
void |
ClusterMonitor.updateNode(RMNode rmNode) |
void |
ClusterMonitor.updateNodeResource(RMNode rmNode,
org.apache.hadoop.yarn.api.records.ResourceOption resourceOption) |
Constructor and Description |
---|
NodesListManagerEvent(NodesListManagerEventType type,
RMNode node) |
Modifier and Type | Method and Description |
---|---|
RMNode |
RMAppNodeUpdateEvent.getNode() |
Modifier and Type | Method and Description |
---|---|
int |
RMApp.pullRMNodeUpdates(Map<RMNode,org.apache.hadoop.yarn.api.records.NodeUpdateType> updatedNodes)
To receive the collection of all
RMNode s whose updates have been
received by the RMApp. |
int |
RMAppImpl.pullRMNodeUpdates(Map<RMNode,org.apache.hadoop.yarn.api.records.NodeUpdateType> upNodes) |
Constructor and Description |
---|
RMAppNodeUpdateEvent(org.apache.hadoop.yarn.api.records.ApplicationId appId,
RMNode node,
RMAppNodeUpdateEvent.RMAppNodeUpdateType updateType) |
Modifier and Type | Class and Description |
---|---|
class |
RMNodeImpl
This class is used to keep track of all the applications/containers
running on a node.
|
Modifier and Type | Method and Description |
---|---|
RMNode |
RMNodeReconnectEvent.getReconnectedNode() |
Constructor and Description |
---|
RMNodeReconnectEvent(org.apache.hadoop.yarn.api.records.NodeId nodeId,
RMNode newNode,
List<org.apache.hadoop.yarn.api.records.ApplicationId> runningApps,
List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerReports) |
Modifier and Type | Method and Description |
---|---|
RMNode |
SchedulerNode.getRMNode() |
Modifier and Type | Method and Description |
---|---|
protected void |
AbstractYarnScheduler.nodeUpdate(RMNode nm)
Process a heartbeat update from a node.
|
void |
AbstractYarnScheduler.recoverContainersOnNode(List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerReports,
RMNode nm) |
void |
AbstractYarnScheduler.updateNodeResource(RMNode nm,
org.apache.hadoop.yarn.api.records.ResourceOption resourceOption)
Process resource update on a node.
|
protected void |
AbstractYarnScheduler.updateNodeResourceUtilization(RMNode nm,
SchedulerNode schedulerNode)
Update container and utilization information on the NodeManager.
|
Constructor and Description |
---|
SchedulerNode(RMNode node,
boolean usePortForNodeName) |
SchedulerNode(RMNode node,
boolean usePortForNodeName,
Set<String> labels) |
Modifier and Type | Method and Description |
---|---|
protected void |
CapacityScheduler.nodeUpdate(RMNode rmNode) |
Constructor and Description |
---|
FiCaSchedulerNode(RMNode node,
boolean usePortForNodeName) |
FiCaSchedulerNode(RMNode node,
boolean usePortForNodeName,
Set<String> nodeLabels) |
Modifier and Type | Method and Description |
---|---|
RMNode |
NodeQueueLoadMonitor.selectAnyNode(Set<String> blacklist) |
RMNode |
NodeQueueLoadMonitor.selectLocalNode(String hostName,
Set<String> blacklist) |
RMNode |
NodeQueueLoadMonitor.selectRackLocalNode(String rackName,
Set<String> blacklist) |
Modifier and Type | Method and Description |
---|---|
void |
NodeQueueLoadMonitor.addNode(List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerStatuses,
RMNode rmNode) |
void |
NodeQueueLoadMonitor.removeNode(RMNode removedRMNode) |
void |
NodeQueueLoadMonitor.updateNode(RMNode rmNode) |
void |
NodeQueueLoadMonitor.updateNodeResource(RMNode rmNode,
org.apache.hadoop.yarn.api.records.ResourceOption resourceOption) |
Modifier and Type | Method and Description |
---|---|
RMNode |
NodeAddedSchedulerEvent.getAddedRMNode() |
RMNode |
NodeRemovedSchedulerEvent.getRemovedRMNode() |
RMNode |
NodeResourceUpdateSchedulerEvent.getRMNode() |
RMNode |
NodeUpdateSchedulerEvent.getRMNode() |
Constructor and Description |
---|
NodeAddedSchedulerEvent(RMNode rmNode) |
NodeAddedSchedulerEvent(RMNode rmNode,
List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerReports) |
NodeRemovedSchedulerEvent(RMNode rmNode) |
NodeResourceUpdateSchedulerEvent(RMNode rmNode,
org.apache.hadoop.yarn.api.records.ResourceOption resourceOption) |
NodeUpdateSchedulerEvent(RMNode rmNode) |
Modifier and Type | Method and Description |
---|---|
protected void |
FairScheduler.nodeUpdate(RMNode nm) |
void |
FairScheduler.updateNodeResource(RMNode nm,
org.apache.hadoop.yarn.api.records.ResourceOption resourceOption)
Process resource update on a node and update Queue.
|
Constructor and Description |
---|
FSSchedulerNode(RMNode node,
boolean usePortForNodeName) |
Modifier and Type | Method and Description |
---|---|
protected void |
FifoScheduler.nodeUpdate(RMNode nm) |
void |
FifoScheduler.recoverContainersOnNode(List<org.apache.hadoop.yarn.server.api.protocolrecords.NMContainerStatus> containerReports,
RMNode nm) |
Constructor and Description |
---|
NodeInfo(RMNode ni,
ResourceScheduler sched) |
ResourceUtilizationInfo(RMNode ni) |
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.