public interface DispatcherGateway extends FencedRpcGateway<DispatcherId>, RestfulGateway
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelJob(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Cancel the given job.
|
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<Acknowledge> |
stopJob(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Stop the given job.
|
CompletableFuture<Acknowledge> |
submitJob(JobGraph jobGraph,
org.apache.flink.api.common.time.Time timeout)
Submit a job to the dispatcher.
|
getFencingToken
requestClusterOverview, requestJob, requestJobDetails, requestMetricQueryServicePaths, requestRestAddress, requestTaskManagerMetricQueryServicePaths
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<Acknowledge> cancelJob(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.Time timeout)
jobId
- identifying the job to canceltimeout
- of the operationCompletableFuture<Acknowledge> stopJob(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.Time timeout)
jobId
- identifying the job to stoptimeout
- of the operationCompletableFuture<Integer> getBlobServerPort(org.apache.flink.api.common.time.Time timeout)
timeout
- of the operationCopyright © 2014–2017 The Apache Software Foundation. All rights reserved.