public class CheckpointResourcesCleanupRunner extends Object implements JobManagerRunner
CheckpointResourcesCleanupRunner
implements JobManagerRunner
in a way, that only
the checkpoint-related resources are instantiated. It triggers any job-specific cleanup that's
usually performed by the JobMaster
without rebuilding the corresponding ExecutionGraph
.Constructor and Description |
---|
CheckpointResourcesCleanupRunner(JobResult jobResult,
CheckpointRecoveryFactory checkpointRecoveryFactory,
SharedStateRegistryFactory sharedStateRegistryFactory,
Configuration jobManagerConfiguration,
Executor cleanupExecutor,
long initializationTimestamp) |
Modifier and Type | Method and Description |
---|---|
CompletableFuture<Acknowledge> |
cancel(Time timeout)
Cancels the currently executed job.
|
CompletableFuture<Void> |
closeAsync()
Trigger the closing of the resource and return the corresponding close future.
|
JobID |
getJobID()
Get the job id of the executed job.
|
CompletableFuture<JobMasterGateway> |
getJobMasterGateway()
Get the
JobMasterGateway of the JobMaster . |
CompletableFuture<JobManagerRunnerResult> |
getResultFuture()
Get the result future of this runner.
|
boolean |
isInitialized()
Flag indicating if the JobManagerRunner has been initialized.
|
CompletableFuture<ExecutionGraphInfo> |
requestJob(Time timeout)
Requests the
ExecutionGraphInfo of the executed job. |
CompletableFuture<JobDetails> |
requestJobDetails(Time timeout)
Request the details of the executed job.
|
CompletableFuture<JobStatus> |
requestJobStatus(Time timeout)
Requests the current job status.
|
void |
start()
Start the execution of the
JobMaster . |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
close
public CheckpointResourcesCleanupRunner(JobResult jobResult, CheckpointRecoveryFactory checkpointRecoveryFactory, SharedStateRegistryFactory sharedStateRegistryFactory, Configuration jobManagerConfiguration, Executor cleanupExecutor, long initializationTimestamp)
public CompletableFuture<Void> closeAsync()
AutoCloseableAsync
closeAsync
in interface AutoCloseableAsync
public void start() throws Exception
JobManagerRunner
JobMaster
.start
in interface JobManagerRunner
Exception
- if the JobMaster cannot be startedpublic CompletableFuture<JobMasterGateway> getJobMasterGateway()
JobManagerRunner
JobMasterGateway
of the JobMaster
. The future is only completed if
the JobMaster becomes leader.getJobMasterGateway
in interface JobManagerRunner
public CompletableFuture<JobManagerRunnerResult> getResultFuture()
JobManagerRunner
JobMaster
fails. If the
result future is completed exceptionally via JobNotFinishedException
, then this
signals that the job has not been completed successfully. All other exceptional completions
denote an unexpected exception which leads to a process restart.getResultFuture
in interface JobManagerRunner
public JobID getJobID()
JobManagerRunner
getJobID
in interface JobManagerRunner
public CompletableFuture<Acknowledge> cancel(Time timeout)
JobManagerRunner
cancel
in interface JobManagerRunner
timeout
- of this operationpublic CompletableFuture<JobStatus> requestJobStatus(Time timeout)
JobManagerRunner
requestJobStatus
in interface JobManagerRunner
timeout
- for the rpc callpublic CompletableFuture<JobDetails> requestJobDetails(Time timeout)
JobManagerRunner
requestJobDetails
in interface JobManagerRunner
timeout
- for the rpc callpublic CompletableFuture<ExecutionGraphInfo> requestJob(Time timeout)
JobManagerRunner
ExecutionGraphInfo
of the executed job.requestJob
in interface JobManagerRunner
timeout
- for the rpc callExecutionGraphInfo
of the executed jobpublic boolean isInitialized()
JobManagerRunner
isInitialized
in interface JobManagerRunner
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.