Package | Description |
---|---|
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.impl | |
org.apache.hadoop.yarn.logaggregation.filecontroller | |
org.apache.hadoop.yarn.security | |
org.apache.hadoop.yarn.security.client | |
org.apache.hadoop.yarn.util |
Modifier and Type | Method and Description |
---|---|
abstract ApplicationAttemptId |
FailApplicationAttemptRequest.getApplicationAttemptId()
Get the
ApplicationAttemptId of the attempt to be failed. |
abstract ApplicationAttemptId |
GetContainersRequest.getApplicationAttemptId()
Get the
ApplicationAttemptId of an application attempt. |
abstract ApplicationAttemptId |
GetApplicationAttemptReportRequest.getApplicationAttemptId()
Get the
ApplicationAttemptId of an application attempt. |
Modifier and Type | Method and Description |
---|---|
static FailApplicationAttemptRequest |
FailApplicationAttemptRequest.newInstance(ApplicationAttemptId attemptId) |
static GetContainersRequest |
GetContainersRequest.newInstance(ApplicationAttemptId applicationAttemptId) |
static GetApplicationAttemptReportRequest |
GetApplicationAttemptReportRequest.newInstance(ApplicationAttemptId applicationAttemptId) |
abstract void |
FailApplicationAttemptRequest.setApplicationAttemptId(ApplicationAttemptId applicationAttemptId) |
abstract void |
GetContainersRequest.setApplicationAttemptId(ApplicationAttemptId applicationAttemptId)
Set the
ApplicationAttemptId of an application attempt |
abstract void |
GetApplicationAttemptReportRequest.setApplicationAttemptId(ApplicationAttemptId applicationAttemptId)
Set the
ApplicationAttemptId of an application attempt |
Modifier and Type | Method and Description |
---|---|
static ApplicationAttemptId |
ApplicationAttemptId.fromString(String appAttemptIdStr) |
abstract ApplicationAttemptId |
ApplicationAttemptReport.getApplicationAttemptId()
Get the
ApplicationAttemptId of this attempt of the
application |
abstract ApplicationAttemptId |
ContainerId.getApplicationAttemptId()
Get the
ApplicationAttemptId of the application to which the
Container was assigned. |
abstract ApplicationAttemptId |
ApplicationReport.getCurrentApplicationAttemptId()
Get the
ApplicationAttemptId of the current
attempt of the application |
static ApplicationAttemptId |
ApplicationAttemptId.newInstance(ApplicationId appId,
int attemptId) |
Modifier and Type | Method and Description |
---|---|
int |
ApplicationAttemptId.compareTo(ApplicationAttemptId other) |
static ContainerId |
ContainerId.newContainerId(ApplicationAttemptId appAttemptId,
long containerId) |
static ApplicationAttemptReport |
ApplicationAttemptReport.newInstance(ApplicationAttemptId applicationAttemptId,
String host,
int rpcPort,
String url,
String oUrl,
String diagnostics,
YarnApplicationAttemptState state,
ContainerId amContainerId) |
Modifier and Type | Field and Description |
---|---|
protected ApplicationAttemptId |
ApplicationMaster.appAttemptID |
Modifier and Type | Method and Description |
---|---|
abstract void |
YarnClient.failApplicationAttempt(ApplicationAttemptId applicationAttemptId)
Fail an application attempt identified by given ID.
|
abstract TimelineEntity |
TimelineReaderClient.getApplicationAttemptEntity(ApplicationAttemptId appAttemptId,
String fields,
Map<String,String> filters)
Gets application attempt entity.
|
abstract ApplicationAttemptReport |
AHSClient.getApplicationAttemptReport(ApplicationAttemptId applicationAttemptId)
Get a report of the given ApplicationAttempt.
|
abstract ApplicationAttemptReport |
YarnClient.getApplicationAttemptReport(ApplicationAttemptId applicationAttemptId)
Get a report of the given ApplicationAttempt.
|
abstract List<ContainerReport> |
AHSClient.getContainers(ApplicationAttemptId applicationAttemptId)
Get a report of all (Containers) of ApplicationAttempt in the cluster.
|
abstract List<ContainerReport> |
YarnClient.getContainers(ApplicationAttemptId applicationAttemptId)
Get a report of all (Containers) of ApplicationAttempt in the cluster.
|
abstract void |
TimelineClient.putDomain(ApplicationAttemptId appAttemptId,
TimelineDomain domain)
Send the information of a domain to the timeline server.
|
abstract TimelinePutResponse |
TimelineClient.putEntities(ApplicationAttemptId appAttemptId,
TimelineEntityGroupId groupId,
TimelineEntity... entities)
Send the information of a number of conceptual entities to the timeline
server.
|
Modifier and Type | Method and Description |
---|---|
TimelineEntity |
TimelineReaderClientImpl.getApplicationAttemptEntity(ApplicationAttemptId appAttemptId,
String fields,
Map<String,String> filters) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
LogAggregationFileController.belongsToAppAttempt(ApplicationAttemptId appAttemptId,
String containerIdStr) |
Modifier and Type | Method and Description |
---|---|
ApplicationAttemptId |
NMTokenIdentifier.getApplicationAttemptId() |
Constructor and Description |
---|
AMRMTokenIdentifier(ApplicationAttemptId appAttemptId,
int masterKeyId) |
NMTokenIdentifier(ApplicationAttemptId appAttemptId,
NodeId nodeId,
String applicationSubmitter,
int masterKeyId) |
Modifier and Type | Method and Description |
---|---|
ApplicationAttemptId |
ClientToAMTokenIdentifier.getApplicationAttemptID() |
Modifier and Type | Method and Description |
---|---|
SecretKey |
ClientToAMTokenSecretManager.getMasterKey(ApplicationAttemptId applicationAttemptID) |
Constructor and Description |
---|
ClientToAMTokenIdentifier(ApplicationAttemptId id,
String client) |
ClientToAMTokenSecretManager(ApplicationAttemptId applicationAttemptID,
byte[] key) |
Modifier and Type | Method and Description |
---|---|
static ApplicationAttemptId |
ConverterUtils.toApplicationAttemptId(String applicationAttemptIdStr)
Deprecated.
|
Copyright © 2023 Apache Software Foundation. All rights reserved.