Package | Description |
---|---|
org.apache.hadoop.yarn.api.protocolrecords | |
org.apache.hadoop.yarn.api.records | |
org.apache.hadoop.yarn.client.api |
Licensed to the Apache Software Foundation (ASF) under one
or more contributor license agreements.
|
org.apache.hadoop.yarn.client.api.async | |
org.apache.hadoop.yarn.logaggregation | |
org.apache.hadoop.yarn.security |
Modifier and Type | Method and Description |
---|---|
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> |
StopContainersRequest.getContainerIds()
Get the
ContainerId s 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> |
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> |
StartContainersResponse.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.
|
Modifier and Type | Method and Description |
---|---|
static GetContainerReportRequest |
GetContainerReportRequest.newInstance(ContainerId containerId) |
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,
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
ContainerId s of containers for which to obtain
the ContainerStatus |
abstract void |
StopContainersRequest.setContainerIds(List<ContainerId> containerIds)
Set the
ContainerId s 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 |
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 |
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 |
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.
|
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 |
ContainerResourceIncreaseRequest.getContainerId() |
abstract ContainerId |
ContainerReport.getContainerId()
Get the
ContainerId of the container. |
abstract ContainerId |
ContainerStatus.getContainerId()
Get the
ContainerId of 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 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,
String nodeHttpAddress) |
abstract void |
ApplicationAttemptReport.setAMContainerId(ContainerId amContainerId) |
abstract void |
ContainerResourceIncreaseRequest.setContainerId(ContainerId containerId) |
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 |
---|---|
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.
|
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.
|
Modifier and Type | Method and Description |
---|---|
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) |
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.yarn.logaggregation.AggregatedLogFormat.ContainerLogsReader |
AggregatedLogFormat.LogReader.getContainerLogsReader(ContainerId containerId)
Get a ContainerLogsReader to read the logs for
the specified container.
|
Constructor and Description |
---|
AggregatedLogFormat.LogKey(ContainerId containerId) |
Modifier and Type | Method and Description |
---|---|
ContainerId |
ContainerTokenIdentifier.getContainerID() |
Constructor and Description |
---|
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) |
Copyright © 2016 Apache Software Foundation. All Rights Reserved.