Uses of Class
org.apache.hadoop.yarn.api.records.NodeId

Packages that use NodeId
org.apache.hadoop.yarn.api.records   
org.apache.hadoop.yarn.client.api   
org.apache.hadoop.yarn.client.api.async   
org.apache.hadoop.yarn.security   
 

Uses of NodeId in org.apache.hadoop.yarn.api.records
 

Methods in org.apache.hadoop.yarn.api.records that return NodeId
abstract  NodeId ContainerReport.getAssignedNode()
          Get the allocated NodeId where container is running.
abstract  NodeId Container.getNodeId()
          Get the identifier of the node on which the container is allocated.
abstract  NodeId NMToken.getNodeId()
          Get the NodeId of the NodeManager for which the NMToken is used to authenticate.
abstract  NodeId NodeReport.getNodeId()
          Get the NodeId of the node.
static NodeId NodeId.newInstance(String host, int port)
           
 

Methods in org.apache.hadoop.yarn.api.records with parameters of type NodeId
 int NodeId.compareTo(NodeId other)
           
static Container Container.newInstance(ContainerId containerId, NodeId nodeId, String nodeHttpAddress, Resource resource, Priority priority, Token containerToken)
           
static ContainerReport ContainerReport.newInstance(ContainerId containerId, Resource allocatedResource, NodeId assignedNode, Priority priority, long startTime, long finishTime, String diagnosticInfo, String logUrl, int containerExitStatus, ContainerState containerState)
           
static NodeReport NodeReport.newInstance(NodeId nodeId, NodeState nodeState, String httpAddress, String rackName, Resource used, Resource capability, int numContainers, String healthReport, long lastHealthReportTime)
           
static NMToken NMToken.newInstance(NodeId nodeId, Token token)
           
abstract  void ContainerReport.setAssignedNode(NodeId nodeId)
           
abstract  void Container.setNodeId(NodeId nodeId)
           
abstract  void NMToken.setNodeId(NodeId nodeId)
           
abstract  void NodeReport.setNodeId(NodeId nodeId)
           
 

Uses of NodeId in org.apache.hadoop.yarn.client.api
 

Methods in org.apache.hadoop.yarn.client.api with parameters of type NodeId
abstract  ContainerStatus NMClient.getContainerStatus(ContainerId containerId, NodeId nodeId)
          Query the status of a container.
abstract  void NMClient.stopContainer(ContainerId containerId, NodeId nodeId)
          Stop an started container.
 

Uses of NodeId in org.apache.hadoop.yarn.client.api.async
 

Methods in org.apache.hadoop.yarn.client.api.async with parameters of type NodeId
abstract  void NMClientAsync.getContainerStatusAsync(ContainerId containerId, NodeId nodeId)
           
abstract  void NMClientAsync.stopContainerAsync(ContainerId containerId, NodeId nodeId)
           
 

Uses of NodeId in org.apache.hadoop.yarn.security
 

Methods in org.apache.hadoop.yarn.security that return NodeId
 NodeId NMTokenIdentifier.getNodeId()
           
 

Constructors in org.apache.hadoop.yarn.security with parameters of type NodeId
NMTokenIdentifier(ApplicationAttemptId appAttemptId, NodeId nodeId, String applicationSubmitter, int masterKeyId)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.