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<ClusterOverview> |
requestClusterOverview(org.apache.flink.api.common.time.Time timeout)
Requests the cluster status overview.
|
CompletableFuture<AccessExecutionGraph> |
requestJob(org.apache.flink.api.common.JobID jobId,
org.apache.flink.api.common.time.Time timeout)
Requests the AccessExecutionGraph for the given jobId.
|
CompletableFuture<MultipleJobsDetails> |
requestJobDetails(boolean includeRunning,
boolean includeFinished,
org.apache.flink.api.common.time.Time timeout)
Requests job details currently being executed on the Flink cluster.
|
CompletableFuture<Collection<String>> |
requestMetricQueryServicePaths(org.apache.flink.api.common.time.Time timeout)
Requests the paths for the
MetricQueryService to query. |
CompletableFuture<String> |
requestRestAddress(org.apache.flink.api.common.time.Time timeout)
Requests the REST address of this
RpcEndpoint . |
CompletableFuture<Collection<org.apache.flink.api.java.tuple.Tuple2<ResourceID,String>>> |
requestTaskManagerMetricQueryServicePaths(org.apache.flink.api.common.time.Time timeout)
Requests the paths for the TaskManager's
MetricQueryService to query. |
getAddress, getHostname
CompletableFuture<String> requestRestAddress(org.apache.flink.api.common.time.Time timeout)
RpcEndpoint
.timeout
- for this operationCompletableFuture<AccessExecutionGraph> requestJob(org.apache.flink.api.common.JobID jobId, org.apache.flink.api.common.time.Time timeout)
FlinkJobNotFoundException
.jobId
- identifying the job whose AccessExecutionGraph is requestedtimeout
- for the asynchronous operationFlinkJobNotFoundException
CompletableFuture<MultipleJobsDetails> requestJobDetails(boolean includeRunning, boolean includeFinished, org.apache.flink.api.common.time.Time timeout)
includeRunning
- true if running jobs shall be included, otherwise falseincludeFinished
- true if finished jobs shall be included, otherwise falsetimeout
- for the asynchronous operationCompletableFuture<ClusterOverview> requestClusterOverview(org.apache.flink.api.common.time.Time timeout)
timeout
- for the asynchronous operationCompletableFuture<Collection<String>> requestMetricQueryServicePaths(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>>> requestTaskManagerMetricQueryServicePaths(org.apache.flink.api.common.time.Time timeout)
MetricQueryService
to query.timeout
- for the asynchronous operationCopyright © 2014–2018 The Apache Software Foundation. All rights reserved.