public interface RestfulGateway extends RpcGateway
Gateways which implement this method run a REST endpoint which is reachable under the returned address.
限定符和类型 | 方法和说明 |
---|---|
CompletableFuture<Acknowledge> |
cancelJob(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Cancel the given job.
|
default CompletableFuture<Acknowledge> |
disposeSavepoint(String savepointPath,
org.apache.flink.api.common.time.Time timeout)
Dispose the given savepoint.
|
CompletableFuture<ClusterOverview> |
requestClusterOverview(org.apache.flink.api.common.time.Time timeout)
Requests the cluster status overview.
|
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<JobResult> |
requestJobResult(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Requests the
JobResult of a job specified by the given jobId. |
default CompletableFuture<org.apache.flink.api.common.JobStatus> |
requestJobStatus(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Request the
JobStatus of the given job. |
CompletableFuture<Collection<String>> |
requestMetricQueryServiceAddresses(org.apache.flink.api.common.time.Time timeout)
Requests the addresses of the
MetricQueryService to query. |
CompletableFuture<MultipleJobsDetails> |
requestMultipleJobDetails(org.apache.flink.api.common.time.Time timeout)
Requests job details currently being executed on the Flink cluster.
|
default CompletableFuture<OperatorBackPressureStatsResponse> |
requestOperatorBackPressureStats(org.apache.flink.api.common.JobID jobId,
JobVertexID jobVertexId)
Requests the statistics on operator back pressure.
|
CompletableFuture<Collection<org.apache.flink.api.java.tuple.Tuple2<ResourceID,String>>> |
requestTaskManagerMetricQueryServiceAddresses(org.apache.flink.api.common.time.Time timeout)
Requests the addresses for the TaskManagers'
MetricQueryService to query. |
default CompletableFuture<Acknowledge> |
shutDownCluster() |
default CompletableFuture<String> |
stopWithSavepoint(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
boolean advanceToEndOfEventTime,
org.apache.flink.api.common.time.Time timeout)
Stops the job with a savepoint.
|
default CompletableFuture<String> |
triggerSavepoint(org.apache.flink.api.common.JobID jobId,
String targetDirectory,
boolean cancelJob,
org.apache.flink.api.common.time.Time timeout)
Triggers a savepoint with the given savepoint directory as a target.
|
getAddress, getHostname
CompletableFuture<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<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
.jobId
- identifying the job whose ArchivedExecutionGraph
is requestedtimeout
- for the asynchronous operationArchivedExecutionGraph
for the given jobId, otherwise FlinkJobNotFoundException
CompletableFuture<JobResult> requestJobResult(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.Time timeout)
JobResult
of a job specified by the given jobId.CompletableFuture<MultipleJobsDetails> requestMultipleJobDetails(org.apache.flink.api.common.time.Time timeout)
timeout
- for the asynchronous operationCompletableFuture<ClusterOverview> requestClusterOverview(org.apache.flink.api.common.time.Time timeout)
timeout
- for the asynchronous operationCompletableFuture<Collection<String>> requestMetricQueryServiceAddresses(org.apache.flink.api.common.time.Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationCompletableFuture<Collection<org.apache.flink.api.java.tuple.Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(org.apache.flink.api.common.time.Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationdefault CompletableFuture<String> triggerSavepoint(org.apache.flink.api.common.JobID jobId, String targetDirectory, boolean cancelJob, org.apache.flink.api.common.time.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(org.apache.flink.api.common.JobID jobId, String targetDirectory, boolean advanceToEndOfEventTime, org.apache.flink.api.common.time.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 usedadvanceToEndOfEventTime
- Flag indicating if the source should inject a MAX_WATERMARK
in the pipeline
to fire any registered event-time timerstimeout
- for the rpc calldefault CompletableFuture<Acknowledge> disposeSavepoint(String savepointPath, org.apache.flink.api.common.time.Time timeout)
savepointPath
- identifying the savepoint to disposetimeout
- RPC timeoutdefault CompletableFuture<org.apache.flink.api.common.JobStatus> requestJobStatus(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.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(org.apache.flink.api.common.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()
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.