public interface DispatcherGateway extends FencedRpcGateway<DispatcherId>, RestfulGateway
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Integer> |
getBlobServerPort(Time timeout)
Returns the port of the blob server.
|
CompletableFuture<Collection<JobID>> |
listJobs(Time timeout)
List the current set of submitted jobs.
|
default CompletableFuture<Acknowledge> |
shutDownCluster(ApplicationStatus applicationStatus) |
default CompletableFuture<String> |
stopWithSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Stops the job with a savepoint, returning a future that completes with the savepoint location
when the savepoint is completed.
|
CompletableFuture<Acknowledge> |
submitFailedJob(JobID jobId,
String jobName,
Throwable exception) |
CompletableFuture<Acknowledge> |
submitJob(JobGraph jobGraph,
Time timeout)
Submit a job to the dispatcher.
|
default CompletableFuture<String> |
triggerCheckpoint(JobID jobID,
Time timeout) |
default CompletableFuture<String> |
triggerSavepointAndGetLocation(JobID jobId,
String targetDirectory,
SavepointFormatType formatType,
TriggerSavepointMode savepointMode,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target, returning a future that
completes with the savepoint location when it is complete.
|
getFencingToken
cancelJob, deliverCoordinationRequestToCoordinator, disposeSavepoint, getTriggeredCheckpointStatus, getTriggeredSavepointStatus, reportJobClientHeartbeat, requestClusterOverview, requestExecutionGraphInfo, requestJob, requestJobResult, requestJobStatus, requestMetricQueryServiceAddresses, requestMultipleJobDetails, requestTaskManagerMetricQueryServiceAddresses, requestThreadDump, shutDownCluster, stopWithSavepoint, triggerCheckpoint, triggerSavepoint
getAddress, getHostname
CompletableFuture<Acknowledge> submitJob(JobGraph jobGraph, Time timeout)
jobGraph
- JobGraph to submittimeout
- RPC timeoutCompletableFuture<Acknowledge> submitFailedJob(JobID jobId, String jobName, Throwable exception)
CompletableFuture<Collection<JobID>> listJobs(Time timeout)
timeout
- RPC timeoutCompletableFuture<Integer> getBlobServerPort(Time timeout)
timeout
- of the operationdefault CompletableFuture<Acknowledge> shutDownCluster(ApplicationStatus applicationStatus)
default CompletableFuture<String> triggerCheckpoint(JobID jobID, Time timeout)
default CompletableFuture<String> triggerSavepointAndGetLocation(JobID jobId, String targetDirectory, SavepointFormatType formatType, TriggerSavepointMode savepointMode, Time timeout)
jobId
- the job idtargetDirectory
- Target directory for the savepoint.formatType
- Binary format of the savepoint.savepointMode
- context of the savepoint operationtimeout
- Timeout for the asynchronous operationdefault CompletableFuture<String> stopWithSavepointAndGetLocation(JobID jobId, String targetDirectory, SavepointFormatType formatType, TriggerSavepointMode savepointMode, Time timeout)
jobId
- the job idtargetDirectory
- Target directory for the savepoint.savepointMode
- context of the savepoint operationtimeout
- for the rpc callCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.