Package | Description |
---|---|
org.apache.hadoop.yarn.ams |
Public api for Application Master Service interceptors.
|
org.apache.hadoop.yarn.api | |
org.apache.hadoop.yarn.conf | |
org.apache.hadoop.yarn.exceptions | |
org.apache.hadoop.yarn.server.api | |
org.apache.hadoop.yarn.util.csi |
Package that includes some CSI utility classes.
|
Modifier and Type | Method and Description |
---|---|
void |
ApplicationMasterServiceProcessor.allocate(ApplicationAttemptId appAttemptId,
AllocateRequest request,
AllocateResponse response)
Allocate call.
|
void |
ApplicationMasterServiceProcessor.registerApplicationMaster(ApplicationAttemptId applicationAttemptId,
RegisterApplicationMasterRequest request,
RegisterApplicationMasterResponse response)
Register AM attempt.
|
Modifier and Type | Method and Description |
---|---|
AllocateResponse |
ApplicationMasterProtocol.allocate(AllocateRequest request)
The main interface between an
ApplicationMaster and the
ResourceManager . |
CancelDelegationTokenResponse |
ApplicationBaseProtocol.cancelDelegationToken(CancelDelegationTokenRequest request)
Cancel an existing delegation
Token . |
CommitResponse |
ContainerManagementProtocol.commitLastReInitialization(ContainerId containerId)
Commit the Last ReInitialization if possible.
|
ReservationDeleteResponse |
ApplicationClientProtocol.deleteReservation(ReservationDeleteRequest request)
The interface used by clients to remove an existing Reservation.
|
FailApplicationAttemptResponse |
ApplicationClientProtocol.failApplicationAttempt(FailApplicationAttemptRequest request)
The interface used by clients to request the
ResourceManager to fail an application attempt. |
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 |
ApplicationBaseProtocol.getApplicationAttemptReport(GetApplicationAttemptReportRequest request)
The interface used by clients to get a report of an Application Attempt
from the
ResourceManager or
ApplicationHistoryServer |
GetApplicationAttemptsResponse |
ApplicationBaseProtocol.getApplicationAttempts(GetApplicationAttemptsRequest request)
The interface used by clients to get a report of all Application attempts
in the cluster from the
ResourceManager or
ApplicationHistoryServer |
GetApplicationReportResponse |
ApplicationBaseProtocol.getApplicationReport(GetApplicationReportRequest request)
The interface used by clients to get a report of an Application from the
ResourceManager or ApplicationHistoryServer . |
GetApplicationsResponse |
ApplicationBaseProtocol.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 or ApplicationHistoryServer . |
GetAttributesToNodesResponse |
ApplicationClientProtocol.getAttributesToNodes(GetAttributesToNodesRequest request)
The interface used by client to get attributes to nodes mappings
available in ResourceManager.
|
GetClusterMetricsResponse |
ApplicationClientProtocol.getClusterMetrics(GetClusterMetricsRequest request)
The interface used by clients to get metrics about the cluster from
the
ResourceManager . |
GetClusterNodeAttributesResponse |
ApplicationClientProtocol.getClusterNodeAttributes(GetClusterNodeAttributesRequest request)
The interface used by client to get node attributes available in
ResourceManager.
|
GetClusterNodeLabelsResponse |
ApplicationClientProtocol.getClusterNodeLabels(GetClusterNodeLabelsRequest request)
The interface used by client to get node labels in the cluster
|
GetClusterNodesResponse |
ApplicationClientProtocol.getClusterNodes(GetClusterNodesRequest request)
The interface used by clients to get a report of all nodes
in the cluster from the
ResourceManager . |
GetContainerReportResponse |
ApplicationBaseProtocol.getContainerReport(GetContainerReportRequest request)
The interface used by clients to get a report of an Container from the
ResourceManager or ApplicationHistoryServer |
GetContainersResponse |
ApplicationBaseProtocol.getContainers(GetContainersRequest request)
The interface used by clients to get a report of Containers for an
application attempt from the
ResourceManager or
ApplicationHistoryServer |
GetContainerStatusesResponse |
ContainerManagementProtocol.getContainerStatuses(GetContainerStatusesRequest request)
The API used by the
ApplicationMaster to request for current
statuses of Container s from the NodeManager . |
GetDelegationTokenResponse |
ApplicationBaseProtocol.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.
|
GetLabelsToNodesResponse |
ApplicationClientProtocol.getLabelsToNodes(GetLabelsToNodesRequest request)
The interface used by client to get labels to nodes mappings
in existing cluster
|
GetLocalizationStatusesResponse |
ContainerManagementProtocol.getLocalizationStatuses(GetLocalizationStatusesRequest request)
API to request for the localization statuses of requested containers from
the Node Manager.
|
GetNewApplicationResponse |
ApplicationClientProtocol.getNewApplication(GetNewApplicationRequest request)
The interface used by clients to obtain a new
ApplicationId for
submitting new applications. |
GetNewReservationResponse |
ApplicationClientProtocol.getNewReservation(GetNewReservationRequest request)
The interface used by clients to obtain a new
ReservationId for
submitting new reservations. |
GetNodesToAttributesResponse |
ApplicationClientProtocol.getNodesToAttributes(GetNodesToAttributesRequest request)
The interface used by client to get node to attributes mappings.
|
GetNodesToLabelsResponse |
ApplicationClientProtocol.getNodeToLabels(GetNodesToLabelsRequest request)
The interface used by client to get node to labels mappings in existing cluster
|
GetPluginInfoResponse |
CsiAdaptorProtocol.getPluginInfo(GetPluginInfoRequest request)
Get plugin info from the CSI driver.
|
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 . |
GetResourceProfileResponse |
ApplicationClientProtocol.getResourceProfile(GetResourceProfileRequest request)
The interface to get the details for a specific resource profile.
|
GetAllResourceProfilesResponse |
ApplicationClientProtocol.getResourceProfiles(GetAllResourceProfilesRequest request)
The interface used by clients to get all the resource profiles that are
available on the ResourceManager.
|
GetAllResourceTypeInfoResponse |
ApplicationClientProtocol.getResourceTypeInfo(GetAllResourceTypeInfoRequest request)
The interface to get the details for a specific resource profile.
|
IncreaseContainersResourceResponse |
ContainerManagementProtocol.increaseContainersResource(IncreaseContainersResourceRequest request)
Deprecated.
|
void |
CsiAdaptorPlugin.init(String driverName,
org.apache.hadoop.conf.Configuration conf)
A csi-adaptor implementation can init its state within this function.
|
ReservationListResponse |
ApplicationClientProtocol.listReservations(ReservationListRequest request)
The interface used by clients to get the list of reservations in a plan.
|
ResourceLocalizationResponse |
ContainerManagementProtocol.localize(ResourceLocalizationRequest request)
Localize resources required by the container.
|
MoveApplicationAcrossQueuesResponse |
ApplicationClientProtocol.moveApplicationAcrossQueues(MoveApplicationAcrossQueuesRequest request)
Move an application to a new queue.
|
NodePublishVolumeResponse |
CsiAdaptorProtocol.nodePublishVolume(NodePublishVolumeRequest request)
Publish the volume on a node manager, the volume will be mounted
to the local file system and become visible for clients.
|
NodeUnpublishVolumeResponse |
CsiAdaptorProtocol.nodeUnpublishVolume(NodeUnpublishVolumeRequest request)
This is a reverse operation of
CsiAdaptorProtocol.nodePublishVolume(NodePublishVolumeRequest) , it un-mounts the
volume from given node. |
RegisterApplicationMasterResponse |
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest request)
The interface used by a new
ApplicationMaster to register with
the ResourceManager . |
ReInitializeContainerResponse |
ContainerManagementProtocol.reInitializeContainer(ReInitializeContainerRequest request)
ReInitialize the Container with a new Launch Context.
|
ReleaseSharedCacheResourceResponse |
ClientSCMProtocol.release(ReleaseSharedCacheResourceRequest request)
The interface used by clients to release a resource with the
SharedCacheManager. This method is called once an application
is no longer using a claimed resource in the shared cache. |
RenewDelegationTokenResponse |
ApplicationBaseProtocol.renewDelegationToken(RenewDelegationTokenRequest request)
Renew an existing delegation
Token . |
RestartContainerResponse |
ContainerManagementProtocol.restartContainer(ContainerId containerId)
Restart the container.
|
RollbackResponse |
ContainerManagementProtocol.rollbackLastReInitialization(ContainerId containerId)
Rollback the Last ReInitialization if possible.
|
SignalContainerResponse |
ContainerManagementProtocol.signalToContainer(SignalContainerRequest request) |
SignalContainerResponse |
ApplicationClientProtocol.signalToContainer(SignalContainerRequest request)
The interface used by clients to request the
ResourceManager to signal a container. |
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. |
ReservationSubmissionResponse |
ApplicationClientProtocol.submitReservation(ReservationSubmissionRequest request)
The interface used by clients to submit a new reservation to the
ResourceManager . |
UpdateApplicationPriorityResponse |
ApplicationClientProtocol.updateApplicationPriority(UpdateApplicationPriorityRequest request)
The interface used by client to set priority of an application.
|
UpdateApplicationTimeoutsResponse |
ApplicationClientProtocol.updateApplicationTimeouts(UpdateApplicationTimeoutsRequest request)
The interface used by client to set ApplicationTimeouts of an application.
|
ContainerUpdateResponse |
ContainerManagementProtocol.updateContainer(ContainerUpdateRequest request)
The API used by the
ApplicationMaster to request for
resource update of running containers on the NodeManager . |
ReservationUpdateResponse |
ApplicationClientProtocol.updateReservation(ReservationUpdateRequest request)
The interface used by clients to update an existing Reservation.
|
UseSharedCacheResourceResponse |
ClientSCMProtocol.use(UseSharedCacheResourceRequest request)
The interface used by clients to claim a resource with the
SharedCacheManager. The client uses a checksum to identify the
resource and an ApplicationId to identify which application will be
using the resource. |
ValidateVolumeCapabilitiesResponse |
CsiAdaptorProtocol.validateVolumeCapacity(ValidateVolumeCapabilitiesRequest request)
Validate if the volume capacity can be satisfied on the underneath
storage system.
|
Modifier and Type | Method and Description |
---|---|
abstract InputStream |
ConfigurationProvider.getConfigurationInputStream(org.apache.hadoop.conf.Configuration bootstrapConf,
String name)
Opens an InputStream at the indicated file
|
Modifier and Type | Class and Description |
---|---|
class |
ApplicationAttemptNotFoundException
This exception is thrown on
(GetApplicationAttemptReportRequest)
API when the Application Attempt doesn't exist in Application History Server or
ApplicationMasterProtocol.allocate(AllocateRequest) if application
doesn't exist in RM. |
class |
ApplicationIdNotProvidedException
Exception to be thrown when Client submit an application without
providing
ApplicationId in ApplicationSubmissionContext . |
class |
ApplicationMasterNotRegisteredException
This exception is thrown when an Application Master tries to unregister by calling
ApplicationMasterProtocol.finishApplicationMaster(FinishApplicationMasterRequest)
API without first registering by calling
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest)
or after an RM restart. |
class |
ApplicationNotFoundException
This exception is thrown on
(GetApplicationReportRequest) API
when the Application doesn't exist in RM and AHS |
class |
ConfigurationException
This exception is thrown on unrecoverable configuration errors.
|
class |
ContainerNotFoundException
This exception is thrown on
(GetContainerReportRequest)
API when the container doesn't exist in AHS |
class |
InvalidApplicationMasterRequestException
This exception is thrown when an ApplicationMaster asks for resources by
calling
ApplicationMasterProtocol.allocate(AllocateRequest)
without first registering by calling
ApplicationMasterProtocol.registerApplicationMaster(RegisterApplicationMasterRequest)
or if it tries to register more than once. |
class |
InvalidAuxServiceException
This exception is thrown by a NodeManager that is rejecting start-container
requests via
ContainerManagementProtocol.startContainers(StartContainersRequest)
for auxservices does not exist. |
class |
InvalidContainerException
This exception is thrown by a NodeManager that is rejecting start-container
requests via
ContainerManagementProtocol.startContainers(StartContainersRequest)
for containers allocated by a previous instance of the RM. |
class |
InvalidContainerReleaseException
This exception is thrown when an Application Master tries to release
containers not belonging to it using
ApplicationMasterProtocol.allocate(AllocateRequest) API. |
class |
InvalidLabelResourceRequestException
This exception is thrown when a resource requested via
ResourceRequest in the
ApplicationMasterProtocol.allocate(AllocateRequest) when requested
label is not having permission to access. |
class |
InvalidResourceBlacklistRequestException
This exception is thrown when an application provides an invalid
ResourceBlacklistRequest specification for blacklisting of resources
in ApplicationMasterProtocol.allocate(AllocateRequest) API. |
class |
InvalidResourceRequestException
This exception is thrown when a resource requested via
ResourceRequest in the
ApplicationMasterProtocol.allocate(AllocateRequest) API is out of the
range of the configured lower and upper limits on resources. |
class |
NMNotYetReadyException
This exception is thrown on
ContainerManagementProtocol.startContainers(StartContainersRequest) API
when an NM starts from scratch but has not yet connected with RM. |
class |
ResourceProfilesNotEnabledException
This exception is thrown when the client requests information about
ResourceProfiles in the
ApplicationClientProtocol but resource
profiles is not enabled on the RM. |
class |
YARNFeatureNotEnabledException
This exception is thrown when a feature is being used which is not enabled
yet.
|
Modifier and Type | Method and Description |
---|---|
static InetSocketAddress |
CsiConfigUtils.getCsiAdaptorAddressForDriver(String driverName,
org.apache.hadoop.conf.Configuration conf)
Resolve the CSI adaptor address for a CSI driver from configuration.
|
static String |
CsiConfigUtils.getCsiDriverEndpoint(String driverName,
org.apache.hadoop.conf.Configuration conf) |
Copyright © 2008–2021 Apache Software Foundation. All rights reserved.