|
||||||||||
PREV NEXT | FRAMES NO FRAMES |
Uses of YarnException in org.apache.hadoop.yarn.api |
---|
Methods in org.apache.hadoop.yarn.api that throw YarnException | |
---|---|
AllocateResponse |
ApplicationMasterProtocol.allocate(AllocateRequest request)
The main interface between an ApplicationMaster and the
ResourceManager . |
org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenResponse |
ApplicationClientProtocol.cancelDelegationToken(org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest request)
Cancel an existing delegation Token . |
org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenResponse |
ApplicationHistoryProtocol.cancelDelegationToken(org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest request)
Cancel an existing delegation token. |
FinishApplicationMasterResponse |
ApplicationMasterProtocol.finishApplicationMaster(FinishApplicationMasterRequest request)
The interface used by an ApplicationMaster to notify the
ResourceManager about its completion (success or failed). |
KillApplicationResponse |
ApplicationClientProtocol.forceKillApplication(KillApplicationRequest request)
The interface used by clients to request the ResourceManager to abort submitted application. |
GetApplicationAttemptReportResponse |
ApplicationClientProtocol.getApplicationAttemptReport(GetApplicationAttemptReportRequest request)
The interface used by clients to get a report of an Application Attempt from the ResourceManager |
GetApplicationAttemptReportResponse |
ApplicationHistoryProtocol.getApplicationAttemptReport(GetApplicationAttemptReportRequest request)
The interface used by clients to get a report of an Application Attempt from the ApplicationHistoryServer . |
GetApplicationAttemptsResponse |
ApplicationClientProtocol.getApplicationAttempts(GetApplicationAttemptsRequest request)
The interface used by clients to get a report of all Application attempts in the cluster from the ResourceManager |
GetApplicationAttemptsResponse |
ApplicationHistoryProtocol.getApplicationAttempts(GetApplicationAttemptsRequest request)
The interface used by clients to get a report of all Application attempts in the cluster from the ApplicationHistoryServer . |
GetApplicationReportResponse |
ApplicationClientProtocol.getApplicationReport(GetApplicationReportRequest request)
The interface used by clients to get a report of an Application from the ResourceManager . |
GetApplicationReportResponse |
ApplicationHistoryProtocol.getApplicationReport(GetApplicationReportRequest request)
The interface used by clients to get a report of an Application from the ResourceManager . |
GetApplicationsResponse |
ApplicationClientProtocol.getApplications(GetApplicationsRequest request)
The interface used by clients to get a report of Applications matching the filters defined by GetApplicationsRequest
in the cluster from the ResourceManager . |
GetApplicationsResponse |
ApplicationHistoryProtocol.getApplications(GetApplicationsRequest request)
The interface used by clients to get a report of all Applications in the cluster from the ApplicationHistoryServer . |
GetClusterMetricsResponse |
ApplicationClientProtocol.getClusterMetrics(GetClusterMetricsRequest request)
The interface used by clients to get metrics about the cluster from the ResourceManager . |
GetClusterNodesResponse |
ApplicationClientProtocol.getClusterNodes(GetClusterNodesRequest request)
The interface used by clients to get a report of all nodes in the cluster from the ResourceManager . |
GetContainerReportResponse |
ApplicationClientProtocol.getContainerReport(GetContainerReportRequest request)
The interface used by clients to get a report of an Container from the ResourceManager |
GetContainerReportResponse |
ApplicationHistoryProtocol.getContainerReport(GetContainerReportRequest request)
The interface used by clients to get a report of an Container from the ApplicationHistoryServer . |
GetContainersResponse |
ApplicationClientProtocol.getContainers(GetContainersRequest request)
The interface used by clients to get a report of Containers for an application attempt from the ResourceManager |
GetContainersResponse |
ApplicationHistoryProtocol.getContainers(GetContainersRequest request)
The interface used by clients to get a report of Containers for an application attempt from the ApplciationHistoryServer . |
GetContainerStatusesResponse |
ContainerManagementProtocol.getContainerStatuses(GetContainerStatusesRequest request)
The API used by the ApplicationMaster to request for current
statuses of Container s from the NodeManager . |
GetDelegationTokenResponse |
ApplicationClientProtocol.getDelegationToken(GetDelegationTokenRequest request)
The interface used by clients to get delegation token, enabling the containers to be able to talk to the service using those tokens. |
GetDelegationTokenResponse |
ApplicationHistoryProtocol.getDelegationToken(GetDelegationTokenRequest request)
The interface used by clients to get delegation token, enabling the containers to be able to talk to the service using those tokens. |
GetNewApplicationResponse |
ApplicationClientProtocol.getNewApplication(GetNewApplicationRequest request)
The interface used by clients to obtain a new ApplicationId for
submitting new applications. |
GetQueueInfoResponse |
ApplicationClientProtocol.getQueueInfo(GetQueueInfoRequest request)
The interface used by clients to get information about queues from the ResourceManager . |
GetQueueUserAclsInfoResponse |
ApplicationClientProtocol.getQueueUserAcls(GetQueueUserAclsInfoRequest request)
The interface used by clients to get information about queue acls for current user from the ResourceManager . |
MoveApplicationAcrossQueuesResponse |
ApplicationClientProtocol.moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest request)
Move an application to a new queue. |
RegisterApplicationMasterResponse |
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest request)
The interface used by a new ApplicationMaster to register with
the ResourceManager . |
org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse |
ApplicationClientProtocol.renewDelegationToken(org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest request)
Renew an existing delegation Token . |
org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse |
ApplicationHistoryProtocol.renewDelegationToken(org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest request)
Renew an existing delegation token. |
StartContainersResponse |
ContainerManagementProtocol.startContainers(StartContainersRequest request)
The ApplicationMaster provides a list of
StartContainerRequest s to a NodeManager to
start Container s allocated to it using this interface. |
StopContainersResponse |
ContainerManagementProtocol.stopContainers(StopContainersRequest request)
The ApplicationMaster requests a NodeManager to
stop a list of Container s allocated to it using this
interface. |
SubmitApplicationResponse |
ApplicationClientProtocol.submitApplication(SubmitApplicationRequest request)
The interface used by clients to submit a new application to the ResourceManager. |
Uses of YarnException in org.apache.hadoop.yarn.applications.distributedshell |
---|
Methods in org.apache.hadoop.yarn.applications.distributedshell that throw YarnException | |
---|---|
boolean |
Client.run()
Main run function for the client |
void |
ApplicationMaster.run()
Main run function for the application master |
Uses of YarnException in org.apache.hadoop.yarn.client.api |
---|
Methods in org.apache.hadoop.yarn.client.api that throw YarnException | |
---|---|
abstract AllocateResponse |
AMRMClient.allocate(float progressIndicator)
Request additional containers and receive new container allocations. |
abstract YarnClientApplication |
YarnClient.createApplication()
Obtain a YarnClientApplication for a new application,
which in turn contains the ApplicationSubmissionContext and
GetNewApplicationResponse
objects. |
abstract List<QueueInfo> |
YarnClient.getAllQueues()
Get information ( QueueInfo ) about all queues, recursively if there
is a hierarchy |
abstract org.apache.hadoop.security.token.Token<AMRMTokenIdentifier> |
YarnClient.getAMRMToken(ApplicationId appId)
Get the AMRM token of the application. |
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<ApplicationAttemptReport> |
AHSClient.getApplicationAttempts(ApplicationId applicationId)
Get a report of all (ApplicationAttempts) of Application in the cluster. |
abstract List<ApplicationAttemptReport> |
YarnClient.getApplicationAttempts(ApplicationId applicationId)
Get a report of all (ApplicationAttempts) of Application in the cluster. |
abstract ApplicationReport |
AHSClient.getApplicationReport(ApplicationId appId)
Get a report of the given Application. |
abstract ApplicationReport |
YarnClient.getApplicationReport(ApplicationId appId)
Get a report of the given Application. |
abstract List<ApplicationReport> |
AHSClient.getApplications()
Get a report (ApplicationReport) of all Applications in the cluster. |
abstract List<ApplicationReport> |
YarnClient.getApplications()
Get a report (ApplicationReport) of all Applications in the cluster. |
abstract List<ApplicationReport> |
YarnClient.getApplications(EnumSet<YarnApplicationState> applicationStates)
Get a report (ApplicationReport) of Applications matching the given application states in the cluster. |
abstract List<ApplicationReport> |
YarnClient.getApplications(Set<String> applicationTypes)
Get a report (ApplicationReport) of Applications matching the given application types in the cluster. |
abstract List<ApplicationReport> |
YarnClient.getApplications(Set<String> applicationTypes,
EnumSet<YarnApplicationState> applicationStates)
Get a report (ApplicationReport) of Applications matching the given application types and application states in the cluster. |
abstract List<QueueInfo> |
YarnClient.getChildQueueInfos(String parent)
Get information ( QueueInfo ) about all the immediate children queues
of the given queue |
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 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 ContainerStatus |
NMClient.getContainerStatus(ContainerId containerId,
NodeId nodeId)
Query the status of a container. |
abstract List<NodeReport> |
YarnClient.getNodeReports(NodeState... states)
Get a report of nodes ( NodeReport ) in the cluster. |
abstract List<QueueUserACLInfo> |
YarnClient.getQueueAclsInfo()
Get information about acls for current user on all the existing queues. |
abstract QueueInfo |
YarnClient.getQueueInfo(String queueName)
Get information ( QueueInfo ) about a given queue. |
abstract Token |
YarnClient.getRMDelegationToken(Text renewer)
Get a delegation token so as to be able to talk to YARN using those tokens. |
abstract List<QueueInfo> |
YarnClient.getRootQueueInfos()
Get information ( QueueInfo ) about top level queues. |
abstract YarnClusterMetrics |
YarnClient.getYarnClusterMetrics()
Get metrics ( YarnClusterMetrics ) about the cluster. |
abstract void |
YarnClient.killApplication(ApplicationId applicationId)
Kill an application identified by given ID. |
abstract void |
YarnClient.moveApplicationAcrossQueues(ApplicationId appId,
String queue)
Attempts to move the given application to the given queue. |
abstract TimelinePutResponse |
TimelineClient.putEntities(TimelineEntity... entities)
Send the information of a number of conceptual entities to the timeline server. |
abstract RegisterApplicationMasterResponse |
AMRMClient.registerApplicationMaster(String appHostName,
int appHostPort,
String appTrackingUrl)
Register the application master. |
abstract Map<String,ByteBuffer> |
NMClient.startContainer(Container container,
ContainerLaunchContext containerLaunchContext)
Start an allocated container. |
abstract void |
NMClient.stopContainer(ContainerId containerId,
NodeId nodeId)
Stop an started container. |
abstract ApplicationId |
YarnClient.submitApplication(ApplicationSubmissionContext appContext)
Submit a new application to YARN. It is a blocking call - it
will not return ApplicationId until the submitted application is
submitted successfully and accepted by the ResourceManager. |
abstract void |
AMRMClient.unregisterApplicationMaster(FinalApplicationStatus appStatus,
String appMessage,
String appTrackingUrl)
Unregister the application master. |
Uses of YarnException in org.apache.hadoop.yarn.client.api.async |
---|
Methods in org.apache.hadoop.yarn.client.api.async that throw YarnException | |
---|---|
abstract RegisterApplicationMasterResponse |
AMRMClientAsync.registerApplicationMaster(String appHostName,
int appHostPort,
String appTrackingUrl)
Registers this application master with the resource manager. |
abstract void |
AMRMClientAsync.unregisterApplicationMaster(FinalApplicationStatus appStatus,
String appMessage,
String appTrackingUrl)
Unregister the application master. |
Uses of YarnException in org.apache.hadoop.yarn.exceptions |
---|
Subclasses of YarnException in org.apache.hadoop.yarn.exceptions | |
---|---|
class |
ApplicationAttemptNotFoundException
This exception is thrown on (GetApplicationAttemptReportRequest)
API when the Application Attempt doesn't exist in Application History Server |
class |
ApplicationIdNotProvidedException
Exception to be thrown when Client submit an application without providing ApplicationId in ApplicationSubmissionContext . |
class |
ApplicationNotFoundException
This exception is thrown on (GetApplicationReportRequest) API
when the Application doesn't exist in RM and AHS |
class |
ContainerNotFoundException
This exception is thrown on (GetContainerReportRequest)
API when the container doesn't exist in AHS |
|
||||||||||
PREV NEXT | FRAMES NO FRAMES |