Package | Description |
---|---|
org.apache.hadoop.yarn.api | |
org.apache.hadoop.yarn.api.protocolrecords | |
org.apache.hadoop.yarn.api.records | |
org.apache.hadoop.yarn.applications.distributedshell |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api | |
org.apache.hadoop.yarn.client.api.async | |
org.apache.hadoop.yarn.client.api.impl | |
org.apache.hadoop.yarn.logaggregation | |
org.apache.hadoop.yarn.security | |
org.apache.hadoop.yarn.util |
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
ContainerId of the container to signal. |
abstract ContainerId |
ReInitializeContainerRequest.getContainerId()
Get the
ContainerId of the container to re-initialize. |
abstract ContainerId |
ResourceLocalizationRequest.getContainerId()
Get the
ContainerId of the container to localize resources. |
abstract ContainerId |
GetContainerReportRequest.getContainerId()
Get the
ContainerId of the Container. |
Modifier and Type | Method and Description |
---|---|
abstract List<ContainerId> |
GetContainerStatusesRequest.getContainerIds()
Get the list of
ContainerId s of containers for which to obtain
the ContainerStatus . |
abstract List<ContainerId> |
GetLocalizationStatusesRequest.getContainerIds()
Get the list of container IDs of the containers for which the localization
statuses are needed.
|
abstract List<ContainerId> |
StopContainersRequest.getContainerIds()
Get the
ContainerId s of the containers to be stopped. |
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> |
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> |
IncreaseContainersResourceResponse.getFailedRequests()
Get the containerId-to-exception map in which the exception indicates
error from each 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 Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> |
ContainerUpdateResponse.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
ContainerId of containers being
released by the ApplicationMaster . |
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
ContainerId s 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
ContainerId of the container to signal. |
abstract void |
GetContainerReportRequest.setContainerId(ContainerId containerId)
Set the
ContainerId of the container |
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 GetContainerStatusesRequest |
GetContainerStatusesRequest.newInstance(List<ContainerId> containerIds) |
static GetLocalizationStatusesRequest |
GetLocalizationStatusesRequest.newInstance(List<ContainerId> containerIds) |
static StopContainersRequest |
StopContainersRequest.newInstance(List<ContainerId> containerIds) |
static ContainerUpdateResponse |
ContainerUpdateResponse.newInstance(List<ContainerId> successfullyUpdatedContainers,
Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests) |
static ContainerUpdateResponse |
ContainerUpdateResponse.newInstance(List<ContainerId> successfullyUpdatedContainers,
Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests) |
static GetLocalizationStatusesResponse |
GetLocalizationStatusesResponse.newInstance(Map<ContainerId,List<LocalizationStatus>> statuses,
Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests) |
static GetLocalizationStatusesResponse |
GetLocalizationStatusesResponse.newInstance(Map<ContainerId,List<LocalizationStatus>> statuses,
Map<ContainerId,org.apache.hadoop.yarn.api.records.SerializedException> failedRequests) |
AllocateRequest.AllocateRequestBuilder |
AllocateRequest.AllocateRequestBuilder.releaseList(List<ContainerId> releaseList)
Set the
releaseList of the request. |
abstract void |
GetContainerStatusesRequest.setContainerIds(List<ContainerId> containerIds)
Set a list of
ContainerId s of containers for which to obtain
the ContainerStatus |
abstract void |
GetLocalizationStatusesRequest.setContainerIds(List<ContainerId> containerIds)
Sets the list of container IDs of containers for which the localization
statuses are needed.
|
abstract void |
StopContainersRequest.setContainerIds(List<ContainerId> containerIds)
Set the
ContainerId s of the containers to be stopped. |
abstract void |
AllocateRequest.setReleaseList(List<ContainerId> releaseContainers)
Set the list of
ContainerId of containers being
released by the ApplicationMaster |
Modifier and Type | Method and Description |
---|---|
static ContainerId |
ContainerId.fromString(String containerIdStr) |
abstract ContainerId |
ApplicationAttemptReport.getAMContainerId()
Get the
ContainerId of AMContainer for this attempt |
abstract ContainerId |
UpdateContainerRequest.getContainerId()
Get the
ContainerId of the container. |
abstract ContainerId |
ContainerStatus.getContainerId()
Get the
ContainerId of the container. |
abstract ContainerId |
ContainerReport.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.newContainerId(ApplicationAttemptId appAttemptId,
long containerId) |
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 UpdateContainerRequest |
UpdateContainerRequest.newInstance(int version,
ContainerId containerId,
ContainerUpdateType updateType,
Resource targetCapability,
ExecutionType targetExecutionType) |
abstract void |
UpdateContainerRequest.setContainerId(ContainerId containerId)
Set the
ContainerId of the container. |
abstract void |
ContainerReport.setContainerId(ContainerId containerId) |
Modifier and Type | Field and Description |
---|---|
protected Set<ContainerId> |
ApplicationMaster.launchedContainers |
Modifier and Type | Method and Description |
---|---|
abstract void |
NMClient.commitLastReInitialization(ContainerId containerId)
Commit last reInitialization of the specified container.
|
abstract TimelineEntity |
TimelineReaderClient.getContainerEntity(ContainerId containerId,
String fields,
Map<String,String> filters)
Gets Timeline entity for the container.
|
abstract ContainerReport |
AHSClient.getContainerReport(ContainerId containerId)
Get a report of the given Container.
|
abstract ContainerReport |
YarnClient.getContainerReport(ContainerId containerId)
Get a report of the given Container.
|
abstract ContainerStatus |
NMClient.getContainerStatus(ContainerId containerId,
NodeId nodeId)
Query the status of a container.
|
List<LocalizationStatus> |
NMClient.getLocalizationStatuses(ContainerId containerId,
NodeId nodeId)
Get the localization statuses of a container.
|
NodeId |
NMClient.getNodeIdOfStartedContainer(ContainerId containerId)
Get the NodeId of the node on which container is running.
|
void |
NMClient.localize(ContainerId containerId,
NodeId nodeId,
Map<String,LocalResource> localResources)
Localize resources for a container.
|
abstract void |
NMClient.reInitializeContainer(ContainerId containerId,
ContainerLaunchContext containerLaunchContex,
boolean autoCommit)
Re-Initialize the Container.
|
abstract void |
AMRMClient.releaseAssignedContainer(ContainerId containerId)
Release containers assigned by the Resource Manager.
|
abstract void |
NMClient.restartContainer(ContainerId containerId)
Restart the specified container.
|
abstract void |
NMClient.rollbackLastReInitialization(ContainerId containerId)
Rollback last reInitialization of the specified container.
|
abstract void |
YarnClient.shellToContainer(ContainerId containerId,
ShellContainerCommand command)
The interface used by client to get a shell to a container.
|
abstract void |
YarnClient.signalToContainer(ContainerId containerId,
SignalContainerCommand command)
Signal a container identified by given ID.
|
abstract void |
NMClient.stopContainer(ContainerId containerId,
NodeId nodeId)
Stop an started container.
|
Modifier and Type | Method and Description |
---|---|
abstract void |
NMClientAsync.commitLastReInitializationAsync(ContainerId containerId)
Commit last reInitialization of the specified container.
|
abstract void |
NMClientAsync.getContainerStatusAsync(ContainerId containerId,
NodeId nodeId) |
abstract void |
NMClientAsync.reInitializeContainerAsync(ContainerId containerId,
ContainerLaunchContext containerLaunchContex,
boolean autoCommit)
Re-Initialize the Container.
|
abstract void |
AMRMClientAsync.releaseAssignedContainer(ContainerId containerId)
Release containers assigned by the Resource Manager.
|
abstract void |
NMClientAsync.restartContainerAsync(ContainerId containerId)
Restart the specified container.
|
abstract void |
NMClientAsync.rollbackLastReInitializationAsync(ContainerId containerId)
Rollback last reInitialization of the specified container.
|
abstract void |
NMClientAsync.stopContainerAsync(ContainerId containerId,
NodeId nodeId) |
Modifier and Type | Method and Description |
---|---|
TimelineEntity |
TimelineReaderClientImpl.getContainerEntity(ContainerId containerId,
String fields,
Map<String,String> filters) |
Constructor and Description |
---|
LogKey(ContainerId containerId) |
Modifier and Type | Method and Description |
---|---|
ContainerId |
ContainerTokenIdentifier.getContainerID() |
Constructor and Description |
---|
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType) |
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType,
long allocationRequestId)
Convenience Constructor for existing clients.
|
ContainerTokenIdentifier(ContainerId containerID,
int containerVersion,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType,
ExecutionType executionType,
long allocationRequestId,
Set<String> allocationTags)
Create a Container Token Identifier.
|
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime) |
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext)
Deprecated.
Use one of the other constructors instead.
|
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression) |
ContainerTokenIdentifier(ContainerId containerID,
String hostName,
String appSubmitter,
Resource r,
long expiryTimeStamp,
int masterKeyId,
long rmIdentifier,
Priority priority,
long creationTime,
LogAggregationContext logAggregationContext,
String nodeLabelExpression,
org.apache.hadoop.yarn.server.api.ContainerType containerType) |
Modifier and Type | Method and Description |
---|---|
static ContainerId |
ConverterUtils.toContainerId(String containerIdStr)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
static String |
ConverterUtils.toString(ContainerId cId)
Deprecated.
|
Copyright © 2023 Apache Software Foundation. All rights reserved.