public interface RestfulGateway extends RpcGateway
Gateways which implement this method run a REST endpoint which is reachable under the returned address.
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelJob(JobID jobId,
Time timeout)
Cancel the given job.
|
default CompletableFuture<CoordinationResponse> |
deliverCoordinationRequestToCoordinator(JobID jobId,
OperatorID operatorId,
SerializedValue<CoordinationRequest> serializedRequest,
Time timeout)
Deliver a coordination request to a specified coordinator and return the response.
|
default CompletableFuture<Acknowledge> |
disposeSavepoint(String savepointPath,
Time timeout)
Dispose the given savepoint.
|
CompletableFuture<ClusterOverview> |
requestClusterOverview(Time timeout)
Requests the cluster status overview.
|
CompletableFuture<ArchivedExecutionGraph> |
requestJob(JobID jobId,
Time timeout)
Requests the
ArchivedExecutionGraph for the given jobId. |
CompletableFuture<JobResult> |
requestJobResult(JobID jobId,
Time timeout)
Requests the
JobResult of a job specified by the given jobId. |
default CompletableFuture<JobStatus> |
requestJobStatus(JobID jobId,
Time timeout)
Request the
JobStatus of the given job. |
CompletableFuture<Collection<String>> |
requestMetricQueryServiceAddresses(Time timeout)
Requests the addresses of the
MetricQueryService to query. |
CompletableFuture<MultipleJobsDetails> |
requestMultipleJobDetails(Time timeout)
Requests job details currently being executed on the Flink cluster.
|
default CompletableFuture<OperatorBackPressureStatsResponse> |
requestOperatorBackPressureStats(JobID jobId,
JobVertexID jobVertexId)
Requests the statistics on operator back pressure.
|
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the addresses for the TaskManagers'
MetricQueryService to query. |
default CompletableFuture<Acknowledge> |
shutDownCluster() |
default CompletableFuture<String> |
stopWithSavepoint(JobID jobId,
String targetDirectory,
boolean terminate,
Time timeout)
Stops the job with a savepoint.
|
default CompletableFuture<String> |
triggerSavepoint(JobID jobId,
String targetDirectory,
boolean cancelJob,
Time timeout)
Triggers a savepoint with the given savepoint directory as a target.
|
getAddress, getHostname
CompletableFuture<Acknowledge> cancelJob(JobID jobId, Time timeout)
jobId
- identifying the job to canceltimeout
- of the operationCompletableFuture<ArchivedExecutionGraph> requestJob(JobID jobId, Time timeout)
ArchivedExecutionGraph
for the given jobId. If there is no such graph,
then the future is completed with a FlinkJobNotFoundException
.jobId
- identifying the job whose ArchivedExecutionGraph
is requestedtimeout
- for the asynchronous operationArchivedExecutionGraph
for the given jobId, otherwise
FlinkJobNotFoundException
CompletableFuture<JobResult> requestJobResult(JobID jobId, Time timeout)
JobResult
of a job specified by the given jobId.CompletableFuture<MultipleJobsDetails> requestMultipleJobDetails(Time timeout)
timeout
- for the asynchronous operationCompletableFuture<ClusterOverview> requestClusterOverview(Time timeout)
timeout
- for the asynchronous operationCompletableFuture<Collection<String>> requestMetricQueryServiceAddresses(Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationCompletableFuture<Collection<Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationdefault CompletableFuture<String> triggerSavepoint(JobID jobId, String targetDirectory, boolean cancelJob, Time timeout)
jobId
- ID of the job for which the savepoint should be triggered.targetDirectory
- Target directory for the savepoint.timeout
- Timeout for the asynchronous operationexternal pointer
of
the savepoint.default CompletableFuture<String> stopWithSavepoint(JobID jobId, String targetDirectory, boolean terminate, Time timeout)
jobId
- ID of the job for which the savepoint should be triggered.targetDirectory
- to which to write the savepoint data or null if the default savepoint
directory should be usedterminate
- flag indicating if the job should terminate or just suspendtimeout
- for the rpc calldefault CompletableFuture<Acknowledge> disposeSavepoint(String savepointPath, Time timeout)
savepointPath
- identifying the savepoint to disposetimeout
- RPC timeoutdefault CompletableFuture<JobStatus> requestJobStatus(JobID jobId, Time timeout)
JobStatus
of the given job.jobId
- identifying the job for which to retrieve the JobStatustimeout
- for the asynchronous operationJobStatus
of the given jobdefault CompletableFuture<OperatorBackPressureStatsResponse> requestOperatorBackPressureStats(JobID jobId, JobVertexID jobVertexId)
jobId
- Job for which the stats are requested.jobVertexId
- JobVertex for which the stats are requested.OperatorBackPressureStatsResponse
.default CompletableFuture<Acknowledge> shutDownCluster()
default CompletableFuture<CoordinationResponse> deliverCoordinationRequestToCoordinator(JobID jobId, OperatorID operatorId, SerializedValue<CoordinationRequest> serializedRequest, Time timeout)
jobId
- identifying the job which the coordinator belongs tooperatorId
- identifying the coordinator to receive the requestserializedRequest
- serialized request to delivertimeout
- RPC timeoutFlinkException
if the task is not running, or no
operator/coordinator exists for the given ID, or the coordinator cannot handle client
events.Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.