public abstract class ResourceManager<WorkerType extends ResourceIDRetrievable> extends FencedRpcEndpoint<ResourceManagerId> implements DelegationTokenManager.Listener, ResourceManagerGateway
It offers the following methods as part of its rpc interface to interact with him remotely:
registerJobMaster(JobMasterId, ResourceID, String, JobID, Time)
registers a JobMaster
at the resource manager
RpcEndpoint.MainThreadExecutor
Modifier and Type | Field and Description |
---|---|
protected BlocklistHandler |
blocklistHandler |
protected Executor |
ioExecutor |
static String |
RESOURCE_MANAGER_NAME |
protected ResourceManagerMetricGroup |
resourceManagerMetricGroup |
log, rpcServer
Constructor and Description |
---|
ResourceManager(RpcService rpcService,
UUID leaderSessionId,
ResourceID resourceId,
HeartbeatServices heartbeatServices,
DelegationTokenManager delegationTokenManager,
SlotManager slotManager,
ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory,
BlocklistHandler.Factory blocklistHandlerFactory,
JobLeaderIdService jobLeaderIdService,
ClusterInformation clusterInformation,
FatalErrorHandler fatalErrorHandler,
ResourceManagerMetricGroup resourceManagerMetricGroup,
Time rpcTimeout,
Executor ioExecutor) |
Modifier and Type | Method and Description |
---|---|
protected void |
closeJobManagerConnection(JobID jobId,
org.apache.flink.runtime.resourcemanager.ResourceManager.ResourceRequirementHandling resourceRequirementHandling,
Exception cause)
This method should be called by the framework once it detects that a currently registered job
manager has failed.
|
protected Optional<WorkerType> |
closeTaskManagerConnection(ResourceID resourceID,
Exception cause)
This method should be called by the framework once it detects that a currently registered
task executor has failed.
|
CompletableFuture<Acknowledge> |
declareRequiredResources(JobMasterId jobMasterId,
ResourceRequirements resourceRequirements,
Time timeout)
Declares the absolute resource requirements for a job.
|
CompletableFuture<Acknowledge> |
deregisterApplication(ApplicationStatus finalStatus,
String diagnostics)
Cleanup application and shut down cluster.
|
void |
disconnectJobManager(JobID jobId,
JobStatus jobStatus,
Exception cause)
Disconnects a JobManager specified by the given resourceID from the
ResourceManager . |
void |
disconnectTaskManager(ResourceID resourceId,
Exception cause)
Disconnects a TaskManager specified by the given resourceID from the
ResourceManager . |
CompletableFuture<List<ShuffleDescriptor>> |
getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
Get the shuffle descriptors of the cluster partitions ordered by partition number.
|
Optional<InstanceID> |
getInstanceIdByResourceId(ResourceID resourceID) |
CompletableFuture<Integer> |
getNumberOfRegisteredTaskManagers()
Gets the currently registered number of TaskManagers.
|
protected abstract CompletableFuture<Void> |
getReadyToServeFuture()
Get the ready to serve future of the resource manager.
|
protected abstract ResourceAllocator |
getResourceAllocator() |
CompletableFuture<Void> |
getStartedFuture()
Completion of this future indicates that the resource manager is fully started and is ready
to serve.
|
protected WorkerType |
getWorkerByInstanceId(InstanceID instanceId) |
protected abstract Optional<WorkerType> |
getWorkerNodeIfAcceptRegistration(ResourceID resourceID)
Get worker node if the worker resource is accepted.
|
CompletableFuture<Void> |
heartbeatFromJobManager(ResourceID resourceID)
Sends the heartbeat to resource manager from job manager.
|
CompletableFuture<Void> |
heartbeatFromTaskManager(ResourceID resourceID,
TaskExecutorHeartbeatPayload heartbeatPayload)
Sends the heartbeat to resource manager from task manager.
|
protected abstract void |
initialize()
Initializes the framework specific components.
|
protected abstract void |
internalDeregisterApplication(ApplicationStatus finalStatus,
String optionalDiagnostics)
The framework specific code to deregister the application.
|
protected void |
jobLeaderLostLeadership(JobID jobId,
JobMasterId oldJobMasterId) |
CompletableFuture<Map<IntermediateDataSetID,DataSetMetaInfo>> |
listDataSets()
Returns all datasets for which partitions are being tracked.
|
CompletableFuture<Acknowledge> |
notifyNewBlockedNodes(Collection<BlockedNode> newNodes)
Notify new blocked node records.
|
void |
notifySlotAvailable(InstanceID instanceID,
SlotID slotId,
AllocationID allocationId)
Sent by the TaskExecutor to notify the ResourceManager that a slot has become available.
|
protected void |
onFatalError(Throwable t)
Notifies the ResourceManager that a fatal error has occurred and it cannot proceed.
|
void |
onNewTokensObtained(byte[] tokens)
Callback function when new delegation tokens obtained.
|
void |
onStart()
User overridable callback which is called from
RpcEndpoint.internalCallOnStart() . |
CompletableFuture<Void> |
onStop()
User overridable callback which is called from
RpcEndpoint.internalCallOnStop() . |
protected void |
onWorkerRegistered(WorkerType worker,
WorkerResourceSpec workerResourceSpec) |
CompletableFuture<RegistrationResponse> |
registerJobMaster(JobMasterId jobMasterId,
ResourceID jobManagerResourceId,
String jobManagerAddress,
JobID jobId,
Time timeout)
Register a
JobMaster at the resource manager. |
protected void |
registerMetrics() |
CompletableFuture<RegistrationResponse> |
registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration,
Time timeout)
Register a
TaskExecutor at the resource manager. |
CompletableFuture<Void> |
releaseClusterPartitions(IntermediateDataSetID dataSetId)
Releases all partitions associated with the given dataset.
|
protected void |
removeJob(JobID jobId,
Exception cause) |
CompletableFuture<Void> |
reportClusterPartitions(ResourceID taskExecutorId,
ClusterPartitionReport clusterPartitionReport)
Report the cluster partitions status in the task executor.
|
CompletableFuture<ResourceOverview> |
requestResourceOverview(Time timeout)
Requests the resource overview.
|
CompletableFuture<TaskExecutorThreadInfoGateway> |
requestTaskExecutorThreadInfoGateway(ResourceID taskManagerId,
Time timeout)
Requests the
TaskExecutorGateway . |
CompletableFuture<TaskManagerInfoWithSlots> |
requestTaskManagerDetailsInfo(ResourceID resourceId,
Time timeout)
Requests detail information about the given
TaskExecutor . |
CompletableFuture<TransientBlobKey> |
requestTaskManagerFileUploadByName(ResourceID taskManagerId,
String fileName,
Time timeout)
Request the file upload from the given
TaskExecutor to the cluster's BlobServer . |
CompletableFuture<TransientBlobKey> |
requestTaskManagerFileUploadByType(ResourceID taskManagerId,
FileType fileType,
Time timeout)
Request the file upload from the given
TaskExecutor to the cluster's BlobServer . |
CompletableFuture<Collection<TaskManagerInfo>> |
requestTaskManagerInfo(Time timeout)
Requests information about the registered
TaskExecutor . |
CompletableFuture<Collection<LogInfo>> |
requestTaskManagerLogList(ResourceID taskManagerId,
Time timeout)
Request log list from the given
TaskExecutor . |
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
CompletableFuture<ThreadDumpInfo> |
requestThreadDump(ResourceID taskManagerId,
Time timeout)
Requests the thread dump from the given
TaskExecutor . |
CompletableFuture<Acknowledge> |
sendSlotReport(ResourceID taskManagerResourceId,
InstanceID taskManagerRegistrationId,
SlotReport slotReport,
Time timeout)
Sends the given
SlotReport to the ResourceManager. |
protected void |
setFailUnfulfillableRequest(boolean failUnfulfillableRequest)
Set
SlotManager whether to fail unfulfillable slot requests. |
void |
stopWorkerIfSupported(WorkerType worker)
Stops the given worker if supported.
|
protected abstract void |
terminate()
Terminates the framework specific components.
|
getFencingToken
callAsync, closeAsync, getAddress, getEndpointId, getHostname, getMainThreadExecutor, getRpcService, getSelfGateway, getTerminationFuture, internalCallOnStart, internalCallOnStop, isRunning, registerResource, runAsync, scheduleRunAsync, scheduleRunAsync, start, stop, unregisterResource, validateRunsInMainThread
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getFencingToken
getAddress, getHostname
close
public static final String RESOURCE_MANAGER_NAME
protected final ResourceManagerMetricGroup resourceManagerMetricGroup
protected final Executor ioExecutor
protected final BlocklistHandler blocklistHandler
public ResourceManager(RpcService rpcService, UUID leaderSessionId, ResourceID resourceId, HeartbeatServices heartbeatServices, DelegationTokenManager delegationTokenManager, SlotManager slotManager, ResourceManagerPartitionTrackerFactory clusterPartitionTrackerFactory, BlocklistHandler.Factory blocklistHandlerFactory, JobLeaderIdService jobLeaderIdService, ClusterInformation clusterInformation, FatalErrorHandler fatalErrorHandler, ResourceManagerMetricGroup resourceManagerMetricGroup, Time rpcTimeout, Executor ioExecutor)
public final void onStart() throws Exception
RpcEndpoint
RpcEndpoint.internalCallOnStart()
.
This method is called when the RpcEndpoint is being started. The method is guaranteed to be executed in the main thread context and can be used to start the rpc endpoint in the context of the rpc endpoint's main thread.
IMPORTANT: This method should never be called directly by the user.
onStart
in class RpcEndpoint
Exception
- indicating that the rpc endpoint could not be started. If an exception
occurs, then the rpc endpoint will automatically terminate.public CompletableFuture<Void> getStartedFuture()
public final CompletableFuture<Void> onStop()
RpcEndpoint
RpcEndpoint.internalCallOnStop()
.
This method is called when the RpcEndpoint is being shut down. The method is guaranteed to be executed in the main thread context and can be used to clean up internal state.
IMPORTANT: This method should never be called directly by the user.
onStop
in class RpcEndpoint
public CompletableFuture<RegistrationResponse> registerJobMaster(JobMasterId jobMasterId, ResourceID jobManagerResourceId, String jobManagerAddress, JobID jobId, Time timeout)
ResourceManagerGateway
JobMaster
at the resource manager.registerJobMaster
in interface ResourceManagerGateway
jobMasterId
- The fencing token for the JobMaster leaderjobManagerResourceId
- The resource ID of the JobMaster that registersjobManagerAddress
- The address of the JobMaster that registersjobId
- The Job ID of the JobMaster that registerstimeout
- Timeout for the future to completepublic CompletableFuture<RegistrationResponse> registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration, Time timeout)
ResourceManagerGateway
TaskExecutor
at the resource manager.registerTaskExecutor
in interface ResourceManagerGateway
taskExecutorRegistration
- the task executor registration.timeout
- The timeout for the response.public CompletableFuture<Acknowledge> sendSlotReport(ResourceID taskManagerResourceId, InstanceID taskManagerRegistrationId, SlotReport slotReport, Time timeout)
ResourceManagerGateway
SlotReport
to the ResourceManager.sendSlotReport
in interface ResourceManagerGateway
taskManagerRegistrationId
- id identifying the sending TaskManagerslotReport
- which is sent to the ResourceManagertimeout
- for the operationAcknowledge
once the slot report has been
received.protected void onWorkerRegistered(WorkerType worker, WorkerResourceSpec workerResourceSpec)
public CompletableFuture<Void> heartbeatFromTaskManager(ResourceID resourceID, TaskExecutorHeartbeatPayload heartbeatPayload)
ResourceManagerGateway
heartbeatFromTaskManager
in interface ResourceManagerGateway
resourceID
- unique id of the task managerheartbeatPayload
- payload from the originating TaskManagerpublic CompletableFuture<Void> heartbeatFromJobManager(ResourceID resourceID)
ResourceManagerGateway
heartbeatFromJobManager
in interface ResourceManagerGateway
resourceID
- unique id of the job managerpublic void disconnectTaskManager(ResourceID resourceId, Exception cause)
ResourceManagerGateway
ResourceManager
.disconnectTaskManager
in interface ResourceManagerGateway
resourceId
- identifying the TaskManager to disconnectcause
- for the disconnection of the TaskManagerpublic void disconnectJobManager(JobID jobId, JobStatus jobStatus, Exception cause)
ResourceManagerGateway
ResourceManager
.disconnectJobManager
in interface ResourceManagerGateway
jobId
- JobID for which the JobManager was the leaderjobStatus
- status of the job at the time of disconnectioncause
- for the disconnection of the JobManagerpublic CompletableFuture<Acknowledge> declareRequiredResources(JobMasterId jobMasterId, ResourceRequirements resourceRequirements, Time timeout)
ResourceManagerGateway
declareRequiredResources
in interface ResourceManagerGateway
jobMasterId
- id of the JobMasterresourceRequirements
- resource requirementspublic void notifySlotAvailable(InstanceID instanceID, SlotID slotId, AllocationID allocationId)
ResourceManagerGateway
notifySlotAvailable
in interface ResourceManagerGateway
instanceID
- TaskExecutor's instance idslotId
- The SlotID of the freed slotallocationId
- to which the slot has been allocatedpublic CompletableFuture<Acknowledge> deregisterApplication(ApplicationStatus finalStatus, @Nullable String diagnostics)
deregisterApplication
in interface ResourceManagerGateway
finalStatus
- of the Flink applicationdiagnostics
- diagnostics message for the Flink application or null
public CompletableFuture<Integer> getNumberOfRegisteredTaskManagers()
ResourceManagerGateway
getNumberOfRegisteredTaskManagers
in interface ResourceManagerGateway
public CompletableFuture<Collection<TaskManagerInfo>> requestTaskManagerInfo(Time timeout)
ResourceManagerGateway
TaskExecutor
.requestTaskManagerInfo
in interface ResourceManagerGateway
timeout
- of the requestpublic CompletableFuture<TaskManagerInfoWithSlots> requestTaskManagerDetailsInfo(ResourceID resourceId, Time timeout)
ResourceManagerGateway
TaskExecutor
.requestTaskManagerDetailsInfo
in interface ResourceManagerGateway
resourceId
- identifying the TaskExecutor for which to return informationtimeout
- of the requestpublic CompletableFuture<ResourceOverview> requestResourceOverview(Time timeout)
ResourceManagerGateway
requestResourceOverview
in interface ResourceManagerGateway
timeout
- of the requestpublic CompletableFuture<Collection<Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(Time timeout)
ResourceManagerGateway
MetricQueryService
to query.requestTaskManagerMetricQueryServiceAddresses
in interface ResourceManagerGateway
timeout
- for the asynchronous operationpublic CompletableFuture<TransientBlobKey> requestTaskManagerFileUploadByType(ResourceID taskManagerId, FileType fileType, Time timeout)
ResourceManagerGateway
TaskExecutor
to the cluster's BlobServer
. The corresponding TransientBlobKey
is returned.requestTaskManagerFileUploadByType
in interface ResourceManagerGateway
taskManagerId
- identifying the TaskExecutor
to upload the specified filefileType
- type of the file to uploadtimeout
- for the asynchronous operationTransientBlobKey
after uploading the file
to the BlobServer
.public CompletableFuture<TransientBlobKey> requestTaskManagerFileUploadByName(ResourceID taskManagerId, String fileName, Time timeout)
ResourceManagerGateway
TaskExecutor
to the cluster's BlobServer
. The corresponding TransientBlobKey
is returned.requestTaskManagerFileUploadByName
in interface ResourceManagerGateway
taskManagerId
- identifying the TaskExecutor
to upload the specified filefileName
- name of the file to uploadtimeout
- for the asynchronous operationTransientBlobKey
after uploading the file
to the BlobServer
.public CompletableFuture<Collection<LogInfo>> requestTaskManagerLogList(ResourceID taskManagerId, Time timeout)
ResourceManagerGateway
TaskExecutor
.requestTaskManagerLogList
in interface ResourceManagerGateway
taskManagerId
- identifying the TaskExecutor
to get log list fromtimeout
- for the asynchronous operationpublic CompletableFuture<Void> releaseClusterPartitions(IntermediateDataSetID dataSetId)
ClusterPartitionManager
releaseClusterPartitions
in interface ClusterPartitionManager
dataSetId
- dataset for which all associated partitions should be releasedpublic CompletableFuture<Void> reportClusterPartitions(ResourceID taskExecutorId, ClusterPartitionReport clusterPartitionReport)
ClusterPartitionManager
reportClusterPartitions
in interface ClusterPartitionManager
taskExecutorId
- The id of the task executor.clusterPartitionReport
- The status of the cluster partitions.public CompletableFuture<List<ShuffleDescriptor>> getClusterPartitionsShuffleDescriptors(IntermediateDataSetID intermediateDataSetID)
ClusterPartitionManager
getClusterPartitionsShuffleDescriptors
in interface ClusterPartitionManager
intermediateDataSetID
- The id of the dataset.public CompletableFuture<Map<IntermediateDataSetID,DataSetMetaInfo>> listDataSets()
ClusterPartitionManager
listDataSets
in interface ClusterPartitionManager
public CompletableFuture<ThreadDumpInfo> requestThreadDump(ResourceID taskManagerId, Time timeout)
ResourceManagerGateway
TaskExecutor
.requestThreadDump
in interface ResourceManagerGateway
taskManagerId
- taskManagerId identifying the TaskExecutor
to get the thread
dump fromtimeout
- timeout of the asynchronous operationpublic CompletableFuture<TaskExecutorThreadInfoGateway> requestTaskExecutorThreadInfoGateway(ResourceID taskManagerId, Time timeout)
ResourceManagerGateway
TaskExecutorGateway
.requestTaskExecutorThreadInfoGateway
in interface ResourceManagerGateway
taskManagerId
- identifying the TaskExecutor
.public CompletableFuture<Acknowledge> notifyNewBlockedNodes(Collection<BlockedNode> newNodes)
BlocklistListener
notifyNewBlockedNodes
in interface BlocklistListener
newNodes
- the new blocked node recordsprotected void registerMetrics()
protected void closeJobManagerConnection(JobID jobId, org.apache.flink.runtime.resourcemanager.ResourceManager.ResourceRequirementHandling resourceRequirementHandling, Exception cause)
jobId
- identifying the job whose leader shall be disconnected.resourceRequirementHandling
- indicating how existing resource requirements for the
corresponding job should be handledcause
- The exception which cause the JobManager failed.protected Optional<WorkerType> closeTaskManagerConnection(ResourceID resourceID, Exception cause)
resourceID
- Id of the TaskManager that has failed.cause
- The exception which cause the TaskManager failed.WorkerType
of the closed connection, or empty if already removed.protected void jobLeaderLostLeadership(JobID jobId, JobMasterId oldJobMasterId)
@VisibleForTesting public Optional<InstanceID> getInstanceIdByResourceId(ResourceID resourceID)
protected WorkerType getWorkerByInstanceId(InstanceID instanceId)
protected void onFatalError(Throwable t)
t
- The exception describing the fatal errorprotected abstract void initialize() throws ResourceManagerException
ResourceManagerException
- which occurs during initialization and causes the resource
manager to fail.protected abstract void terminate() throws Exception
Exception
- which occurs during termination.protected abstract void internalDeregisterApplication(ApplicationStatus finalStatus, @Nullable String optionalDiagnostics) throws ResourceManagerException
This method also needs to make sure all pending containers that are not registered yet are returned.
finalStatus
- The application status to report.optionalDiagnostics
- A diagnostics message or null
.ResourceManagerException
- if the application could not be shut down.protected abstract Optional<WorkerType> getWorkerNodeIfAcceptRegistration(ResourceID resourceID)
resourceID
- The worker resource idpublic void stopWorkerIfSupported(WorkerType worker)
worker
- The worker.protected abstract CompletableFuture<Void> getReadyToServeFuture()
protected abstract ResourceAllocator getResourceAllocator()
protected void setFailUnfulfillableRequest(boolean failUnfulfillableRequest)
SlotManager
whether to fail unfulfillable slot requests.failUnfulfillableRequest
- whether to fail unfulfillable requestspublic void onNewTokensObtained(byte[] tokens) throws Exception
DelegationTokenManager.Listener
onNewTokensObtained
in interface DelegationTokenManager.Listener
Exception
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.