public class NonLeaderRetrievalRestfulGateway extends Object implements RestfulGateway
Gateways which implement this method run a REST endpoint which is reachable under the returned
address, and can be used in AbstractHandler
without
leader retrieval logic.
Modifier and Type | Field and Description |
---|---|
static NonLeaderRetrievalRestfulGateway |
INSTANCE |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancelJob(JobID jobId,
Time timeout)
Cancel the given job.
|
String |
getAddress()
Returns the fully qualified address under which the associated rpc endpoint is reachable.
|
String |
getHostname()
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
|
CompletableFuture<ClusterOverview> |
requestClusterOverview(Time timeout)
Requests the cluster status overview.
|
CompletableFuture<ExecutionGraphInfo> |
requestExecutionGraphInfo(JobID jobId,
Time timeout)
Requests the
ExecutionGraphInfo containing additional information besides the ArchivedExecutionGraph . |
CompletableFuture<JobResult> |
requestJobResult(JobID jobId,
Time timeout)
Requests the
JobResult of a job specified by the given jobId. |
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.
|
CompletableFuture<Collection<Tuple2<ResourceID,String>>> |
requestTaskManagerMetricQueryServiceAddresses(Time timeout)
Requests the addresses for the TaskManagers'
MetricQueryService to query. |
CompletableFuture<ThreadDumpInfo> |
requestThreadDump(Time timeout)
Requests the thread dump from the JobManager.
|
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
deliverCoordinationRequestToCoordinator, disposeSavepoint, getTriggeredSavepointStatus, requestJob, requestJobStatus, shutDownCluster, stopWithSavepoint, triggerSavepoint
public static final NonLeaderRetrievalRestfulGateway INSTANCE
public String getAddress()
RpcGateway
getAddress
in interface RpcGateway
public String getHostname()
RpcGateway
getHostname
in interface RpcGateway
public CompletableFuture<Acknowledge> cancelJob(JobID jobId, Time timeout)
RestfulGateway
cancelJob
in interface RestfulGateway
jobId
- identifying the job to canceltimeout
- of the operationpublic CompletableFuture<ExecutionGraphInfo> requestExecutionGraphInfo(JobID jobId, Time timeout)
RestfulGateway
ExecutionGraphInfo
containing additional information besides the ArchivedExecutionGraph
. If there is no such graph, then the future is completed with a
FlinkJobNotFoundException
.requestExecutionGraphInfo
in interface RestfulGateway
jobId
- identifying the job whose ExecutionGraphInfo
is requestedtimeout
- for the asynchronous operationExecutionGraphInfo
for the given jobId, otherwise
FlinkJobNotFoundException
public CompletableFuture<JobResult> requestJobResult(JobID jobId, Time timeout)
RestfulGateway
JobResult
of a job specified by the given jobId.requestJobResult
in interface RestfulGateway
jobId
- identifying the job for which to retrieve the JobResult
.timeout
- for the asynchronous operationJobResult
once the job has finishedpublic CompletableFuture<MultipleJobsDetails> requestMultipleJobDetails(Time timeout)
RestfulGateway
requestMultipleJobDetails
in interface RestfulGateway
timeout
- for the asynchronous operationpublic CompletableFuture<ClusterOverview> requestClusterOverview(Time timeout)
RestfulGateway
requestClusterOverview
in interface RestfulGateway
timeout
- for the asynchronous operationpublic CompletableFuture<Collection<String>> requestMetricQueryServiceAddresses(Time timeout)
RestfulGateway
MetricQueryService
to query.requestMetricQueryServiceAddresses
in interface RestfulGateway
timeout
- for the asynchronous operationpublic CompletableFuture<Collection<Tuple2<ResourceID,String>>> requestTaskManagerMetricQueryServiceAddresses(Time timeout)
RestfulGateway
MetricQueryService
to query.requestTaskManagerMetricQueryServiceAddresses
in interface RestfulGateway
timeout
- for the asynchronous operationpublic CompletableFuture<ThreadDumpInfo> requestThreadDump(Time timeout)
RestfulGateway
requestThreadDump
in interface RestfulGateway
timeout
- timeout of the asynchronous operationCopyright © 2014–2024 The Apache Software Foundation. All rights reserved.