public interface DispatcherGateway extends FencedRpcGateway<DispatcherId>, RestfulGateway
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Integer> |
getBlobServerPort(org.apache.flink.api.common.time.Time timeout)
Returns the port of the blob server.
|
CompletableFuture<Collection<org.apache.flink.api.common.JobID>> |
listJobs(org.apache.flink.api.common.time.Time timeout)
List the current set of submitted jobs.
|
CompletableFuture<ArchivedExecutionGraph> |
requestJob(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Requests the
ArchivedExecutionGraph for the given jobId. |
CompletableFuture<Acknowledge> |
submitJob(JobGraph jobGraph,
org.apache.flink.api.common.time.Time timeout)
Submit a job to the dispatcher.
|
getFencingToken
cancelJob, disposeSavepoint, requestClusterOverview, requestJobResult, requestJobStatus, requestMetricQueryServicePaths, requestMultipleJobDetails, requestOperatorBackPressureStats, requestRestAddress, requestTaskManagerMetricQueryServicePaths, rescaleJob, shutDownCluster, stopJob, triggerSavepoint
getAddress, getHostname
CompletableFuture<Acknowledge> submitJob(JobGraph jobGraph, org.apache.flink.api.common.time.Time timeout)
jobGraph
- JobGraph to submittimeout
- RPC timeoutCompletableFuture<Collection<org.apache.flink.api.common.JobID>> listJobs(org.apache.flink.api.common.time.Time timeout)
timeout
- RPC timeoutCompletableFuture<Integer> getBlobServerPort(org.apache.flink.api.common.time.Time timeout)
timeout
- of the operationCompletableFuture<ArchivedExecutionGraph> requestJob(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.Time timeout)
ArchivedExecutionGraph
for the given jobId. If there is no such graph, then
the future is completed with a FlinkJobNotFoundException
.
Note: We enforce that the returned future contains a ArchivedExecutionGraph
unlike
the super interface.
requestJob
in interface RestfulGateway
jobId
- identifying the job whose AccessExecutionGraph is requestedtimeout
- for the asynchronous operationFlinkJobNotFoundException
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.