public interface ResourceManagerGateway extends FencedRpcGateway<ResourceManagerId>, ClusterPartitionManager, BlocklistListener
ResourceManager
's RPC gateway interface.Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
declareRequiredResources(JobMasterId jobMasterId,
ResourceRequirements resourceRequirements,
Time timeout)
Declares the absolute resource requirements for a job.
|
CompletableFuture<Acknowledge> |
deregisterApplication(ApplicationStatus finalStatus,
String diagnostics)
Deregister Flink from the underlying resource management system.
|
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<Integer> |
getNumberOfRegisteredTaskManagers()
Gets the currently registered number of TaskManagers.
|
CompletableFuture<Void> |
heartbeatFromJobManager(ResourceID heartbeatOrigin)
Sends the heartbeat to resource manager from job manager.
|
CompletableFuture<Void> |
heartbeatFromTaskManager(ResourceID heartbeatOrigin,
TaskExecutorHeartbeatPayload heartbeatPayload)
Sends the heartbeat to resource manager from task manager.
|
void |
notifySlotAvailable(InstanceID instanceId,
SlotID slotID,
AllocationID oldAllocationId)
Sent by the TaskExecutor to notify the ResourceManager that a slot has become available.
|
CompletableFuture<RegistrationResponse> |
registerJobMaster(JobMasterId jobMasterId,
ResourceID jobMasterResourceId,
String jobMasterAddress,
JobID jobId,
Time timeout)
Register a
JobMaster at the resource manager. |
CompletableFuture<RegistrationResponse> |
registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration,
Time timeout)
Register a
TaskExecutor at the resource manager. |
CompletableFuture<ProfilingInfo> |
requestProfiling(ResourceID taskManagerId,
int duration,
ProfilingInfo.ProfilingMode mode,
Duration timeout)
Requests the profiling instance from the given
TaskExecutor . |
CompletableFuture<ResourceOverview> |
requestResourceOverview(Time timeout)
Requests the resource overview.
|
CompletableFuture<TaskExecutorThreadInfoGateway> |
requestTaskExecutorThreadInfoGateway(ResourceID taskManagerId,
Time timeout)
Requests the
TaskExecutorGateway . |
CompletableFuture<TaskManagerInfoWithSlots> |
requestTaskManagerDetailsInfo(ResourceID taskManagerId,
Time timeout)
Requests detail information about the given
TaskExecutor . |
CompletableFuture<TransientBlobKey> |
requestTaskManagerFileUploadByName(ResourceID taskManagerId,
String fileName,
Time timeout)
Deprecated.
|
CompletableFuture<TransientBlobKey> |
requestTaskManagerFileUploadByNameAndType(ResourceID taskManagerId,
String fileName,
FileType fileType,
Duration 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<Collection<ProfilingInfo>> |
requestTaskManagerProfilingList(ResourceID taskManagerId,
Duration timeout)
Request profiling list from the given
TaskExecutor . |
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. |
getFencingToken
getAddress, getHostname
getClusterPartitionsShuffleDescriptors, listDataSets, releaseClusterPartitions, reportClusterPartitions
notifyNewBlockedNodes
CompletableFuture<RegistrationResponse> registerJobMaster(JobMasterId jobMasterId, ResourceID jobMasterResourceId, String jobMasterAddress, JobID jobId, Time timeout)
JobMaster
at the resource manager.jobMasterId
- The fencing token for the JobMaster leaderjobMasterResourceId
- The resource ID of the JobMaster that registersjobMasterAddress
- The address of the JobMaster that registersjobId
- The Job ID of the JobMaster that registerstimeout
- Timeout for the future to completeCompletableFuture<Acknowledge> declareRequiredResources(JobMasterId jobMasterId, ResourceRequirements resourceRequirements, Time timeout)
jobMasterId
- id of the JobMasterresourceRequirements
- resource requirementsCompletableFuture<RegistrationResponse> registerTaskExecutor(TaskExecutorRegistration taskExecutorRegistration, Time timeout)
TaskExecutor
at the resource manager.taskExecutorRegistration
- the task executor registration.timeout
- The timeout for the response.CompletableFuture<Acknowledge> sendSlotReport(ResourceID taskManagerResourceId, InstanceID taskManagerRegistrationId, SlotReport slotReport, Time timeout)
SlotReport
to the ResourceManager.taskManagerRegistrationId
- id identifying the sending TaskManagerslotReport
- which is sent to the ResourceManagertimeout
- for the operationAcknowledge
once the slot report has been
received.void notifySlotAvailable(InstanceID instanceId, SlotID slotID, AllocationID oldAllocationId)
instanceId
- TaskExecutor's instance idslotID
- The SlotID of the freed slotoldAllocationId
- to which the slot has been allocatedCompletableFuture<Acknowledge> deregisterApplication(ApplicationStatus finalStatus, @Nullable String diagnostics)
finalStatus
- final status with which to deregister the Flink applicationdiagnostics
- additional information for the resource management system, can be null
CompletableFuture<Integer> getNumberOfRegisteredTaskManagers()
CompletableFuture<Void> heartbeatFromTaskManager(ResourceID heartbeatOrigin, TaskExecutorHeartbeatPayload heartbeatPayload)
heartbeatOrigin
- unique id of the task managerheartbeatPayload
- payload from the originating TaskManagerCompletableFuture<Void> heartbeatFromJobManager(ResourceID heartbeatOrigin)
heartbeatOrigin
- unique id of the job managervoid disconnectTaskManager(ResourceID resourceID, Exception cause)
ResourceManager
.resourceID
- identifying the TaskManager to disconnectcause
- for the disconnection of the TaskManagervoid disconnectJobManager(JobID jobId, JobStatus jobStatus, Exception cause)
ResourceManager
.jobId
- JobID for which the JobManager was the leaderjobStatus
- status of the job at the time of disconnectioncause
- for the disconnection of the JobManagerCompletableFuture<Collection<TaskManagerInfo>> requestTaskManagerInfo(Time timeout)
TaskExecutor
.timeout
- of the requestCompletableFuture<TaskManagerInfoWithSlots> requestTaskManagerDetailsInfo(ResourceID taskManagerId, Time timeout)
TaskExecutor
.taskManagerId
- identifying the TaskExecutor for which to return informationtimeout
- of the requestCompletableFuture<ResourceOverview> requestResourceOverview(Time timeout)
timeout
- of the requestCompletableFuture<Collection<Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationCompletableFuture<TransientBlobKey> requestTaskManagerFileUploadByType(ResourceID taskManagerId, FileType fileType, Time timeout)
TaskExecutor
to the cluster's BlobServer
. The corresponding TransientBlobKey
is returned.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
.@Deprecated CompletableFuture<TransientBlobKey> requestTaskManagerFileUploadByName(ResourceID taskManagerId, String fileName, Time timeout)
requestTaskManagerFileUploadByNameAndType(ResourceID, String,
FileType, Duration)
as instead.TaskExecutor
to the cluster's BlobServer
. The corresponding TransientBlobKey
is returned. To support different
type file upload with name, using ResourceManager.requestTaskManagerFileUploadByNameAndType(org.apache.flink.runtime.clusterframework.types.ResourceID, java.lang.String, org.apache.flink.runtime.taskexecutor.FileType, java.time.Duration)
as instead.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
.CompletableFuture<TransientBlobKey> requestTaskManagerFileUploadByNameAndType(ResourceID taskManagerId, String fileName, FileType fileType, Duration timeout)
TaskExecutor
to the cluster's BlobServer
. The corresponding TransientBlobKey
is returned.taskManagerId
- identifying the TaskExecutor
to upload the specified filefileName
- name of the file to uploadfileType
- type of the file to uploadtimeout
- for the asynchronous operationTransientBlobKey
after uploading the file
to the BlobServer
.CompletableFuture<Collection<LogInfo>> requestTaskManagerLogList(ResourceID taskManagerId, Time timeout)
TaskExecutor
.taskManagerId
- identifying the TaskExecutor
to get log list fromtimeout
- for the asynchronous operationCompletableFuture<ThreadDumpInfo> requestThreadDump(ResourceID taskManagerId, Time timeout)
TaskExecutor
.taskManagerId
- taskManagerId identifying the TaskExecutor
to get the thread
dump fromtimeout
- timeout of the asynchronous operationCompletableFuture<TaskExecutorThreadInfoGateway> requestTaskExecutorThreadInfoGateway(ResourceID taskManagerId, Time timeout)
TaskExecutorGateway
.taskManagerId
- identifying the TaskExecutor
.CompletableFuture<Collection<ProfilingInfo>> requestTaskManagerProfilingList(ResourceID taskManagerId, Duration timeout)
TaskExecutor
.taskManagerId
- identifying the TaskExecutor
to get profiling list fromtimeout
- for the asynchronous operationCompletableFuture<ProfilingInfo> requestProfiling(ResourceID taskManagerId, int duration, ProfilingInfo.ProfilingMode mode, Duration timeout)
TaskExecutor
.taskManagerId
- taskManagerId identifying the TaskExecutor
to get the profiling
fromduration
- profiling durationmode
- profiling mode ProfilingInfo.ProfilingMode
timeout
- timeout of the asynchronous operationCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.