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

Packages that use ContainerId
org.apache.hadoop.yarn.api.protocolrecords   
org.apache.hadoop.yarn.api.records   
org.apache.hadoop.yarn.client.api   
org.apache.hadoop.yarn.client.api.async   
org.apache.hadoop.yarn.logaggregation   
org.apache.hadoop.yarn.security   
 

Uses of ContainerId in org.apache.hadoop.yarn.api.protocolrecords
 

Methods in org.apache.hadoop.yarn.api.protocolrecords that return ContainerId
abstract  ContainerId GetContainerReportRequest.getContainerId()
          Get the ContainerId of the Container.
 

Methods in org.apache.hadoop.yarn.api.protocolrecords that return types with arguments of type ContainerId
abstract  List<ContainerId> GetContainerStatusesRequest.getContainerIds()
          Get the list of ContainerIds of containers for which to obtain the ContainerStatus.
abstract  List<ContainerId> StopContainersRequest.getContainerIds()
          Get the ContainerIds of the containers to be stopped.
abstract  Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> StopContainersResponse.getFailedRequests()
          Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> StartContainersResponse.getFailedRequests()
          Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> GetContainerStatusesResponse.getFailedRequests()
          Get the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  List<ContainerId> AllocateRequest.getReleaseList()
          Get the list of ContainerId of containers being released by the ApplicationMaster.
abstract  List<ContainerId> StartContainersResponse.getSuccessfullyStartedContainers()
          Get the list of ContainerId s of the containers that are started successfully.
abstract  List<ContainerId> StopContainersResponse.getSuccessfullyStoppedContainers()
          Get the list of containerIds of successfully stopped containers.
 

Methods in org.apache.hadoop.yarn.api.protocolrecords with parameters of type ContainerId
static GetContainerReportRequest GetContainerReportRequest.newInstance(ContainerId containerId)
           
abstract  void GetContainerReportRequest.setContainerId(ContainerId containerId)
          Set the ContainerId of the container
 

Method parameters in org.apache.hadoop.yarn.api.protocolrecords with type arguments of type ContainerId
static AllocateRequest AllocateRequest.newInstance(int responseID, float appProgress, List<ResourceRequest> resourceAsk, List<ContainerId> containersToBeReleased, ResourceBlacklistRequest resourceBlacklistRequest)
           
static AllocateRequest AllocateRequest.newInstance(int responseID, float appProgress, List<ResourceRequest> resourceAsk, List<ContainerId> containersToBeReleased, ResourceBlacklistRequest resourceBlacklistRequest, List<ContainerResourceIncreaseRequest> increaseRequests)
           
static GetContainerStatusesRequest GetContainerStatusesRequest.newInstance(List<ContainerId> containerIds)
           
static StopContainersRequest StopContainersRequest.newInstance(List<ContainerId> containerIds)
           
static StopContainersResponse StopContainersResponse.newInstance(List<ContainerId> succeededRequests, Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests)
           
static StopContainersResponse StopContainersResponse.newInstance(List<ContainerId> succeededRequests, Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests)
           
static GetContainerStatusesResponse GetContainerStatusesResponse.newInstance(List<ContainerStatus> statuses, Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests)
           
static StartContainersResponse StartContainersResponse.newInstance(Map<String,ByteBuffer> servicesMetaData, List<ContainerId> succeededContainers, Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedContainers)
           
static StartContainersResponse StartContainersResponse.newInstance(Map<String,ByteBuffer> servicesMetaData, List<ContainerId> succeededContainers, Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedContainers)
           
abstract  void GetContainerStatusesRequest.setContainerIds(List<ContainerId> containerIds)
          Set a list of ContainerIds of containers for which to obtain the ContainerStatus
abstract  void StopContainersRequest.setContainerIds(List<ContainerId> containerIds)
          Set the ContainerIds of the containers to be stopped.
abstract  void StopContainersResponse.setFailedRequests(Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests)
          Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  void StartContainersResponse.setFailedRequests(Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedContainers)
          Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  void GetContainerStatusesResponse.setFailedRequests(Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedContainers)
          Set the containerId-to-exception map in which the exception indicates error from per container for failed requests
abstract  void AllocateRequest.setReleaseList(List<ContainerId> releaseContainers)
          Set the list of ContainerId of containers being released by the ApplicationMaster
abstract  void StartContainersResponse.setSuccessfullyStartedContainers(List<ContainerId> succeededContainers)
           
abstract  void StopContainersResponse.setSuccessfullyStoppedContainers(List<ContainerId> succeededRequests)
          Set the list of containerIds of successfully stopped containers.
 

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

Methods in org.apache.hadoop.yarn.api.records that return ContainerId
abstract  ContainerId ApplicationAttemptReport.getAMContainerId()
          Get the ContainerId of AMContainer for this attempt
abstract  ContainerId ContainerReport.getContainerId()
          Get the ContainerId of the container.
abstract  ContainerId ContainerResourceIncreaseRequest.getContainerId()
           
abstract  ContainerId ContainerStatus.getContainerId()
          Get the ContainerId of the container.
abstract  ContainerId PreemptionContainer.getId()
           
abstract  ContainerId Container.getId()
          Get the globally unique identifier for the container.
static ContainerId ContainerId.newInstance(ApplicationAttemptId appAttemptId, int containerId)
           
 

Methods in org.apache.hadoop.yarn.api.records with parameters of type ContainerId
 int ContainerId.compareTo(ContainerId other)
           
static ApplicationAttemptReport ApplicationAttemptReport.newInstance(ApplicationAttemptId applicationAttemptId, String host, int rpcPort, String url, String diagnostics, YarnApplicationAttemptState state, ContainerId amContainerId)
           
static PreemptionContainer PreemptionContainer.newInstance(ContainerId id)
           
static ContainerStatus ContainerStatus.newInstance(ContainerId containerId, ContainerState containerState, String diagnostics, int exitStatus)
           
static Container Container.newInstance(ContainerId containerId, NodeId nodeId, String nodeHttpAddress, Resource resource, Priority priority, Token containerToken)
           
static ContainerResourceIncreaseRequest ContainerResourceIncreaseRequest.newInstance(ContainerId existingContainerId, Resource targetCapability)
           
static ContainerReport ContainerReport.newInstance(ContainerId containerId, Resource allocatedResource, NodeId assignedNode, Priority priority, long creationTime, long finishTime, String diagnosticInfo, String logUrl, int containerExitStatus, ContainerState containerState)
           
abstract  void ApplicationAttemptReport.setAMContainerId(ContainerId amContainerId)
           
abstract  void ContainerReport.setContainerId(ContainerId containerId)
           
abstract  void ContainerResourceIncreaseRequest.setContainerId(ContainerId containerId)
           
abstract  void ContainerStatus.setContainerId(ContainerId containerId)
           
abstract  void PreemptionContainer.setId(ContainerId id)
           
abstract  void Container.setId(ContainerId id)
           
 

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

Methods in org.apache.hadoop.yarn.client.api with parameters of type ContainerId
abstract  ContainerReport YarnClient.getContainerReport(ContainerId containerId)
           Get a report of the given Container.
abstract  ContainerReport AHSClient.getContainerReport(ContainerId containerId)
           Get a report of the given Container.
abstract  ContainerStatus NMClient.getContainerStatus(ContainerId containerId, NodeId nodeId)
          Query the status of a container.
abstract  void AMRMClient.releaseAssignedContainer(ContainerId containerId)
          Release containers assigned by the Resource Manager.
abstract  void NMClient.stopContainer(ContainerId containerId, NodeId nodeId)
          Stop an started container.
 

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

Methods in org.apache.hadoop.yarn.client.api.async with parameters of type ContainerId
abstract  void NMClientAsync.getContainerStatusAsync(ContainerId containerId, NodeId nodeId)
           
abstract  void AMRMClientAsync.releaseAssignedContainer(ContainerId containerId)
          Release containers assigned by the Resource Manager.
abstract  void NMClientAsync.stopContainerAsync(ContainerId containerId, NodeId nodeId)
           
 

Uses of ContainerId in org.apache.hadoop.yarn.logaggregation
 

Methods in org.apache.hadoop.yarn.logaggregation with parameters of type ContainerId
 org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.ContainerLogsReader AggregatedLogFormat.LogReader.getContainerLogsReader(ContainerId containerId)
          Get a ContainerLogsReader to read the logs for the specified container.
 

Constructors in org.apache.hadoop.yarn.logaggregation with parameters of type ContainerId
AggregatedLogFormat.LogKey(ContainerId containerId)
           
 

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

Methods in org.apache.hadoop.yarn.security that return ContainerId
 ContainerId ContainerTokenIdentifier.getContainerID()
           
 

Constructors in org.apache.hadoop.yarn.security with parameters of type ContainerId
ContainerTokenIdentifier(ContainerId containerID, String hostName, String appSubmitter, Resource r, long expiryTimeStamp, int masterKeyId, long rmIdentifier, Priority priority, long creationTime)
           
 



Copyright © 2014 Apache Software Foundation. All Rights Reserved.