| Package | Description | 
|---|---|
| org.apache.hadoop.yarn.api | |
| org.apache.hadoop.yarn.api.protocolrecords | |
| org.apache.hadoop.yarn.api.records | |
| org.apache.hadoop.yarn.server.api | 
| Modifier and Type | Method and Description | 
|---|---|
| CommitResponse | ContainerManagementProtocol. commitLastReInitialization(ContainerId containerId)Commit the Last ReInitialization if possible. | 
| RestartContainerResponse | ContainerManagementProtocol. restartContainer(ContainerId containerId)Restart the container. | 
| RollbackResponse | ContainerManagementProtocol. rollbackLastReInitialization(ContainerId containerId)Rollback the Last ReInitialization if possible. | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract ContainerId | SignalContainerRequest. getContainerId()Get the  ContainerIdof the container to signal. | 
| abstract ContainerId | ReInitializeContainerRequest. getContainerId()Get the  ContainerIdof the container to re-initialize. | 
| abstract ContainerId | GetContainerReportRequest. getContainerId()Get the  ContainerIdof the Container. | 
| abstract ContainerId | ResourceLocalizationRequest. getContainerId()Get the  ContainerIdof the container to localize resources. | 
| Modifier and Type | Method and Description | 
|---|---|
| abstract List<ContainerId> | GetLocalizationStatusesRequest. getContainerIds()Get the list of container IDs of the containers for which the localization
 statuses are needed. | 
| abstract List<ContainerId> | GetContainerStatusesRequest. getContainerIds()Get the list of  ContainerIds of containers for which to obtain
 theContainerStatus. | 
| abstract List<ContainerId> | StopContainersRequest. getContainerIds()Get the  ContainerIds of the containers to be stopped. | 
| abstract Map<ContainerId,SerializedException> | GetContainerStatusesResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract Map<ContainerId,SerializedException> | StopContainersResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract Map<ContainerId,SerializedException> | ContainerUpdateResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates
 error from each container for failed requests. | 
| abstract Map<ContainerId,SerializedException> | StartContainersResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract Map<ContainerId,SerializedException> | GetLocalizationStatusesResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates error
 from per container for failed requests. | 
| abstract Map<ContainerId,SerializedException> | IncreaseContainersResourceResponse. getFailedRequests()Get the containerId-to-exception map in which the exception indicates
 error from each container for failed requests. | 
| abstract Map<ContainerId,List<LocalizationStatus>> | GetLocalizationStatusesResponse. getLocalizationStatuses()Get all the container localization statuses. | 
| abstract List<ContainerId> | AllocateRequest. getReleaseList()Get the list of  ContainerIdof containers being 
 released by theApplicationMaster. | 
| abstract List<ContainerId> | IncreaseContainersResourceResponse. getSuccessfullyIncreasedContainers()Get the list of containerIds of containers whose resource
 have been successfully increased. | 
| abstract List<ContainerId> | StartContainersResponse. getSuccessfullyStartedContainers()Get the list of  ContainerIds of the containers that are
 started successfully. | 
| abstract List<ContainerId> | StopContainersResponse. getSuccessfullyStoppedContainers()Get the list of containerIds of successfully stopped containers. | 
| abstract List<ContainerId> | ContainerUpdateResponse. getSuccessfullyUpdatedContainers()Get the list of containerIds of containers whose resource
 have been successfully update. | 
| Modifier and Type | Method and Description | 
|---|---|
| static GetContainerReportRequest | GetContainerReportRequest. newInstance(ContainerId containerId) | 
| static ReInitializeContainerRequest | ReInitializeContainerRequest. newInstance(ContainerId containerId,
           ContainerLaunchContext containerLaunchContext,
           boolean autoCommit)Creates a new instance of the ReInitializationContainerRequest. | 
| static ResourceLocalizationRequest | ResourceLocalizationRequest. newInstance(ContainerId containerId,
           Map<String,LocalResource> localResources) | 
| static SignalContainerRequest | SignalContainerRequest. newInstance(ContainerId containerId,
           SignalContainerCommand signalContainerCommand) | 
| abstract void | SignalContainerRequest. setContainerId(ContainerId containerId)Set the  ContainerIdof the container to signal. | 
| abstract void | ReInitializeContainerRequest. setContainerId(ContainerId containerId)Set the  ContainerIdof the container to re-initialize. | 
| abstract void | GetContainerReportRequest. setContainerId(ContainerId containerId)Set the  ContainerIdof the container | 
| abstract void | ResourceLocalizationRequest. setContainerId(ContainerId containerId)Set the  ContainerIdof the container to localize resources. | 
| Modifier and Type | Method and Description | 
|---|---|
| static AllocateRequest | AllocateRequest. newInstance(int responseID,
           float appProgress,
           List<ResourceRequest> resourceAsk,
           List<ContainerId> containersToBeReleased,
           List<UpdateContainerRequest> updateRequests,
           ResourceBlacklistRequest resourceBlacklistRequest) | 
| 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,
           String trackingUrl) | 
| static GetLocalizationStatusesRequest | GetLocalizationStatusesRequest. newInstance(List<ContainerId> containerIds) | 
| static GetContainerStatusesRequest | GetContainerStatusesRequest. newInstance(List<ContainerId> containerIds) | 
| static StopContainersRequest | StopContainersRequest. newInstance(List<ContainerId> containerIds) | 
| static StopContainersResponse | StopContainersResponse. newInstance(List<ContainerId> succeededRequests,
           Map<ContainerId,SerializedException> failedRequests) | 
| static StopContainersResponse | StopContainersResponse. newInstance(List<ContainerId> succeededRequests,
           Map<ContainerId,SerializedException> failedRequests) | 
| static ContainerUpdateResponse | ContainerUpdateResponse. newInstance(List<ContainerId> successfullyUpdatedContainers,
           Map<ContainerId,SerializedException> failedRequests) | 
| static ContainerUpdateResponse | ContainerUpdateResponse. newInstance(List<ContainerId> successfullyUpdatedContainers,
           Map<ContainerId,SerializedException> failedRequests) | 
| static IncreaseContainersResourceResponse | IncreaseContainersResourceResponse. newInstance(List<ContainerId> successfullyIncreasedContainers,
           Map<ContainerId,SerializedException> failedRequests) | 
| static IncreaseContainersResourceResponse | IncreaseContainersResourceResponse. newInstance(List<ContainerId> successfullyIncreasedContainers,
           Map<ContainerId,SerializedException> failedRequests) | 
| static GetContainerStatusesResponse | GetContainerStatusesResponse. newInstance(List<ContainerStatus> statuses,
           Map<ContainerId,SerializedException> failedRequests) | 
| static GetLocalizationStatusesResponse | GetLocalizationStatusesResponse. newInstance(Map<ContainerId,List<LocalizationStatus>> statuses,
           Map<ContainerId,SerializedException> failedRequests) | 
| static GetLocalizationStatusesResponse | GetLocalizationStatusesResponse. newInstance(Map<ContainerId,List<LocalizationStatus>> statuses,
           Map<ContainerId,SerializedException> failedRequests) | 
| static StartContainersResponse | StartContainersResponse. newInstance(Map<String,ByteBuffer> servicesMetaData,
           List<ContainerId> succeededContainers,
           Map<ContainerId,SerializedException> failedContainers) | 
| static StartContainersResponse | StartContainersResponse. newInstance(Map<String,ByteBuffer> servicesMetaData,
           List<ContainerId> succeededContainers,
           Map<ContainerId,SerializedException> failedContainers) | 
| AllocateRequest.AllocateRequestBuilder | AllocateRequest.AllocateRequestBuilder. releaseList(List<ContainerId> releaseList)Set the  releaseListof the request. | 
| abstract void | GetLocalizationStatusesRequest. setContainerIds(List<ContainerId> containerIds)Sets the list of container IDs of containers for which the localization
 statuses are needed. | 
| abstract void | GetContainerStatusesRequest. setContainerIds(List<ContainerId> containerIds)Set a list of  ContainerIds of containers for which to obtain
 theContainerStatus | 
| abstract void | StopContainersRequest. setContainerIds(List<ContainerId> containerIds)Set the  ContainerIds of the containers to be stopped. | 
| abstract void | GetContainerStatusesResponse. setFailedRequests(Map<ContainerId,SerializedException> failedContainers)Set the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract void | StopContainersResponse. setFailedRequests(Map<ContainerId,SerializedException> failedRequests)Set the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract void | ContainerUpdateResponse. setFailedRequests(Map<ContainerId,SerializedException> failedRequests)Set the containerId-to-exception map in which the exception indicates
 error from each container for failed requests. | 
| abstract void | StartContainersResponse. setFailedRequests(Map<ContainerId,SerializedException> failedContainers)Set the containerId-to-exception map in which the exception indicates error
 from per container for failed requests | 
| abstract void | GetLocalizationStatusesResponse. setFailedRequests(Map<ContainerId,SerializedException> failedContainers)Set the containerId-to-exception map in which the exception indicates error
 from per container for failed request. | 
| abstract void | IncreaseContainersResourceResponse. setFailedRequests(Map<ContainerId,SerializedException> failedRequests)Set the containerId-to-exception map in which the exception indicates
 error from each container for failed requests. | 
| abstract void | GetLocalizationStatusesResponse. setLocalizationStatuses(Map<ContainerId,List<LocalizationStatus>> statuses)Sets the container localization statuses. | 
| abstract void | AllocateRequest. setReleaseList(List<ContainerId> releaseContainers)Set the list of  ContainerIdof containers being
 released by theApplicationMaster | 
| abstract void | IncreaseContainersResourceResponse. setSuccessfullyIncreasedContainers(List<ContainerId> succeedIncreasedContainers)Set the list of containerIds of containers whose resource have
 been successfully increased. | 
| abstract void | StartContainersResponse. setSuccessfullyStartedContainers(List<ContainerId> succeededContainers) | 
| abstract void | StopContainersResponse. setSuccessfullyStoppedContainers(List<ContainerId> succeededRequests)Set the list of containerIds of successfully stopped containers. | 
| abstract void | ContainerUpdateResponse. setSuccessfullyUpdatedContainers(List<ContainerId> succeedUpdatedContainers)Set the list of containerIds of containers whose resource have
 been successfully updated. | 
| Modifier and Type | Method and Description | 
|---|---|
| static ContainerId | ContainerId. fromString(String containerIdStr) | 
| abstract ContainerId | ApplicationAttemptReport. getAMContainerId()Get the  ContainerIdof AMContainer for this attempt | 
| abstract ContainerId | UpdateContainerRequest. getContainerId()Get the  ContainerIdof the container. | 
| abstract ContainerId | ContainerReport. getContainerId()Get the  ContainerIdof the container. | 
| abstract ContainerId | ContainerStatus. getContainerId()Get the  ContainerIdof the container. | 
| abstract ContainerId | Container. getId()Get the globally unique identifier for the container. | 
| abstract ContainerId | PreemptionContainer. getId() | 
| static ContainerId | ContainerId. newContainerId(ApplicationAttemptId appAttemptId,
              long containerId) | 
| static ContainerId | ContainerId. newInstance(ApplicationAttemptId appAttemptId,
           int containerId)Deprecated.  | 
| Modifier and Type | Method and Description | 
|---|---|
| int | ContainerId. compareTo(ContainerId other) | 
| static ApplicationAttemptReport | ApplicationAttemptReport. newInstance(ApplicationAttemptId applicationAttemptId,
           String host,
           int rpcPort,
           String url,
           String oUrl,
           String diagnostics,
           YarnApplicationAttemptState state,
           ContainerId amContainerId) | 
| static ApplicationAttemptReport | ApplicationAttemptReport. newInstance(ApplicationAttemptId applicationAttemptId,
           String host,
           int rpcPort,
           String url,
           String oUrl,
           String diagnostics,
           YarnApplicationAttemptState state,
           ContainerId amContainerId,
           long startTime,
           long finishTime) | 
| static PreemptionContainer | PreemptionContainer. newInstance(ContainerId id) | 
| static ContainerStatus | ContainerStatus. newInstance(ContainerId containerId,
           ContainerState containerState,
           String diagnostics,
           int exitStatus) | 
| static ContainerStatus | ContainerStatus. newInstance(ContainerId containerId,
           ExecutionType executionType,
           ContainerState containerState,
           String diagnostics,
           int exitStatus) | 
| static Container | Container. newInstance(ContainerId containerId,
           NodeId nodeId,
           String nodeHttpAddress,
           Resource resource,
           Priority priority,
           Token containerToken) | 
| static Container | Container. newInstance(ContainerId containerId,
           NodeId nodeId,
           String nodeHttpAddress,
           Resource resource,
           Priority priority,
           Token containerToken,
           ExecutionType executionType) | 
| static ContainerReport | ContainerReport. newInstance(ContainerId containerId,
           Resource allocatedResource,
           NodeId assignedNode,
           Priority priority,
           long creationTime,
           long finishTime,
           String diagnosticInfo,
           String logUrl,
           int containerExitStatus,
           ContainerState containerState,
           String nodeHttpAddress) | 
| static ContainerReport | ContainerReport. newInstance(ContainerId containerId,
           Resource allocatedResource,
           NodeId assignedNode,
           Priority priority,
           long creationTime,
           long finishTime,
           String diagnosticInfo,
           String logUrl,
           int containerExitStatus,
           ContainerState containerState,
           String nodeHttpAddress,
           ExecutionType executionType) | 
| static UpdateContainerRequest | UpdateContainerRequest. newInstance(int version,
           ContainerId containerId,
           ContainerUpdateType updateType,
           Resource targetCapability,
           ExecutionType targetExecutionType) | 
| abstract void | ApplicationAttemptReport. setAMContainerId(ContainerId amContainerId) | 
| abstract void | UpdateContainerRequest. setContainerId(ContainerId containerId)Set the  ContainerIdof the container. | 
| abstract void | ContainerReport. setContainerId(ContainerId containerId) | 
| abstract void | ContainerStatus. setContainerId(ContainerId containerId) | 
| abstract void | Container. setId(ContainerId id) | 
| abstract void | PreemptionContainer. setId(ContainerId id) | 
| Modifier and Type | Method and Description | 
|---|---|
| ContainerId | ContainerLogContext. getContainerId()Get  ContainerIdof the container. | 
| ContainerId | ContainerContext. getContainerId()Get  ContainerIdof the container being initialized or stopped. | 
| Constructor and Description | 
|---|
| ContainerContext(String user,
                ContainerId containerId,
                Resource resource) | 
| ContainerContext(String user,
                ContainerId containerId,
                Resource resource,
                ContainerType containerType) | 
| ContainerContext(String user,
                ContainerId containerId,
                Resource resource,
                ContainerType containerType,
                ExecutionType executionType) | 
| ContainerInitializationContext(String user,
                              ContainerId containerId,
                              Resource resource) | 
| ContainerInitializationContext(String user,
                              ContainerId containerId,
                              Resource resource,
                              ContainerType containerType) | 
| ContainerLogContext(ContainerId containerId,
                   ContainerType containerType,
                   int exitCode) | 
| ContainerTerminationContext(String user,
                           ContainerId containerId,
                           Resource resource) | 
| ContainerTerminationContext(String user,
                           ContainerId containerId,
                           Resource resource,
                           ContainerType containerType) | 
Copyright © 2008–2023 Apache Software Foundation. All rights reserved.