Class EmbeddedJobClient
- java.lang.Object
-
- org.apache.flink.client.deployment.application.EmbeddedJobClient
-
- All Implemented Interfaces:
org.apache.flink.core.execution.JobClient,org.apache.flink.runtime.operators.coordination.CoordinationRequestGateway
@Internal public class EmbeddedJobClient extends Object implements org.apache.flink.core.execution.JobClient, org.apache.flink.runtime.operators.coordination.CoordinationRequestGateway
AJobClientwith the ability to also submit jobs which uses directly theDispatcherGateway.
-
-
Constructor Summary
Constructors Constructor Description EmbeddedJobClient(org.apache.flink.api.common.JobID jobId, org.apache.flink.runtime.dispatcher.DispatcherGateway dispatcherGateway, org.apache.flink.util.concurrent.ScheduledExecutor retryExecutor, Duration rpcTimeout, ClassLoader classLoader)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description CompletableFuture<Void>cancel()CompletableFuture<Map<String,Object>>getAccumulators()CompletableFuture<org.apache.flink.api.common.JobExecutionResult>getJobExecutionResult()org.apache.flink.api.common.JobIDgetJobID()CompletableFuture<org.apache.flink.api.common.JobStatus>getJobStatus()CompletableFuture<org.apache.flink.runtime.operators.coordination.CoordinationResponse>sendCoordinationRequest(String operatorUid, org.apache.flink.runtime.operators.coordination.CoordinationRequest request)CompletableFuture<String>stopWithSavepoint(boolean advanceToEndOfEventTime, String savepointDirectory, org.apache.flink.core.execution.SavepointFormatType formatType)CompletableFuture<String>triggerSavepoint(String savepointDirectory, org.apache.flink.core.execution.SavepointFormatType formatType)
-
-
-
Constructor Detail
-
EmbeddedJobClient
public EmbeddedJobClient(org.apache.flink.api.common.JobID jobId, org.apache.flink.runtime.dispatcher.DispatcherGateway dispatcherGateway, org.apache.flink.util.concurrent.ScheduledExecutor retryExecutor, Duration rpcTimeout, ClassLoader classLoader)
-
-
Method Detail
-
getJobID
public org.apache.flink.api.common.JobID getJobID()
- Specified by:
getJobIDin interfaceorg.apache.flink.core.execution.JobClient
-
getJobStatus
public CompletableFuture<org.apache.flink.api.common.JobStatus> getJobStatus()
- Specified by:
getJobStatusin interfaceorg.apache.flink.core.execution.JobClient
-
cancel
public CompletableFuture<Void> cancel()
- Specified by:
cancelin interfaceorg.apache.flink.core.execution.JobClient
-
stopWithSavepoint
public CompletableFuture<String> stopWithSavepoint(boolean advanceToEndOfEventTime, @Nullable String savepointDirectory, org.apache.flink.core.execution.SavepointFormatType formatType)
- Specified by:
stopWithSavepointin interfaceorg.apache.flink.core.execution.JobClient
-
triggerSavepoint
public CompletableFuture<String> triggerSavepoint(@Nullable String savepointDirectory, org.apache.flink.core.execution.SavepointFormatType formatType)
- Specified by:
triggerSavepointin interfaceorg.apache.flink.core.execution.JobClient
-
getAccumulators
public CompletableFuture<Map<String,Object>> getAccumulators()
- Specified by:
getAccumulatorsin interfaceorg.apache.flink.core.execution.JobClient
-
getJobExecutionResult
public CompletableFuture<org.apache.flink.api.common.JobExecutionResult> getJobExecutionResult()
- Specified by:
getJobExecutionResultin interfaceorg.apache.flink.core.execution.JobClient
-
sendCoordinationRequest
public CompletableFuture<org.apache.flink.runtime.operators.coordination.CoordinationResponse> sendCoordinationRequest(String operatorUid, org.apache.flink.runtime.operators.coordination.CoordinationRequest request)
- Specified by:
sendCoordinationRequestin interfaceorg.apache.flink.runtime.operators.coordination.CoordinationRequestGateway
-
-