public interface JobManagerGateway extends RestfulGateway
This interface constitutes the operations an external component can trigger on the JobManager.
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelJob(JobID jobId,
Time timeout)
Cancels the given job.
|
CompletableFuture<String> |
cancelJobWithSavepoint(JobID jobId,
String savepointPath,
Time timeout)
Cancels the given job after taking a savepoint and returning its path.
|
CompletableFuture<Integer> |
requestBlobServerPort(Time timeout)
Requests the BlobServer port.
|
CompletableFuture<Optional<org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps>> |
requestClassloadingProps(JobID jobId,
Time timeout)
Requests the class loading properties for the given JobID.
|
CompletableFuture<JobIdsWithStatusOverview> |
requestJobsOverview(Time timeout)
Requests the job overview from the JobManager.
|
CompletableFuture<Optional<Instance>> |
requestTaskManagerInstance(ResourceID resourceId,
Time timeout)
Requests the TaskManager instance registered under the given instanceId from the JobManager.
|
CompletableFuture<Collection<Instance>> |
requestTaskManagerInstances(Time timeout)
Requests all currently registered TaskManager instances from the JobManager.
|
CompletableFuture<Acknowledge> |
stopJob(JobID jobId,
Time timeout)
Stops the given job.
|
CompletableFuture<Acknowledge> |
submitJob(JobGraph jobGraph,
ListeningBehaviour listeningBehaviour,
Time timeout)
Submits a job to the JobManager.
|
disposeSavepoint, requestClusterOverview, requestJob, requestJobResult, requestJobStatus, requestMetricQueryServicePaths, requestMultipleJobDetails, requestOperatorBackPressureStats, requestRestAddress, requestTaskManagerMetricQueryServicePaths, rescaleJob, shutDownCluster, triggerSavepoint
getAddress, getHostname
CompletableFuture<Integer> requestBlobServerPort(Time timeout)
timeout
- for this operationCompletableFuture<Acknowledge> submitJob(JobGraph jobGraph, ListeningBehaviour listeningBehaviour, Time timeout)
jobGraph
- to submitlisteningBehaviour
- of the clienttimeout
- for this operationCompletableFuture<String> cancelJobWithSavepoint(JobID jobId, @Nullable String savepointPath, Time timeout)
jobId
- identifying the job to cancelsavepointPath
- Optional path for the savepoint to be stored under; if null, then the default path is
takentimeout
- for the asynchronous operationCompletableFuture<Acknowledge> cancelJob(JobID jobId, Time timeout)
cancelJob
in interface RestfulGateway
jobId
- identifying the job to canceltimeout
- for the asynchronous operationCompletableFuture<Acknowledge> stopJob(JobID jobId, Time timeout)
stopJob
in interface RestfulGateway
jobId
- identifying the job to canceltimeout
- for the asynchronous operationCompletableFuture<Optional<org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps>> requestClassloadingProps(JobID jobId, Time timeout)
jobId
- for which the class loading properties are requestedtimeout
- for this operationCompletableFuture<Optional<Instance>> requestTaskManagerInstance(ResourceID resourceId, Time timeout)
Optional.empty()
is returned.resourceId
- identifying the TaskManager which shall be retrievedtimeout
- for the asynchronous operationOptional.empty()
CompletableFuture<Collection<Instance>> requestTaskManagerInstances(Time timeout)
timeout
- for the asynchronous operationCompletableFuture<JobIdsWithStatusOverview> requestJobsOverview(Time timeout)
timeout
- for the asynchronous operationCopyright © 2014–2019 The Apache Software Foundation. All rights reserved.