@NotThreadSafe public class PendingCheckpoint extends Object implements Checkpoint
CompletedCheckpoint
.
Note that the pending checkpoint, as well as the successful checkpoint keep the state handles always as serialized values, never as actual values.
Modifier and Type | Class and Description |
---|---|
class |
PendingCheckpoint.PendingCheckpointDiscardObject
Implementation of
Checkpoint.DiscardObject for
PendingCheckpoint . |
static class |
PendingCheckpoint.TaskAcknowledgeResult
Result of the
acknowledgedTasks method. |
Checkpoint.DiscardObject
NOOP_DISCARD_OBJECT
Constructor and Description |
---|
PendingCheckpoint(JobID jobId,
long checkpointId,
long checkpointTimestamp,
CheckpointPlan checkpointPlan,
Collection<OperatorID> operatorCoordinatorsToConfirm,
Collection<String> masterStateIdentifiers,
CheckpointProperties props,
CompletableFuture<CompletedCheckpoint> onCompletionPromise,
PendingCheckpointStats pendingCheckpointStats,
CompletableFuture<Void> masterTriggerCompletionPromise) |
public PendingCheckpoint(JobID jobId, long checkpointId, long checkpointTimestamp, CheckpointPlan checkpointPlan, Collection<OperatorID> operatorCoordinatorsToConfirm, Collection<String> masterStateIdentifiers, CheckpointProperties props, CompletableFuture<CompletedCheckpoint> onCompletionPromise, @Nullable PendingCheckpointStats pendingCheckpointStats, CompletableFuture<Void> masterTriggerCompletionPromise)
public JobID getJobId()
public long getCheckpointID()
getCheckpointID
in interface Checkpoint
public void setCheckpointTargetLocation(CheckpointStorageLocation targetLocation)
public CheckpointStorageLocation getCheckpointStorageLocation()
public long getCheckpointTimestamp()
public int getNumberOfNonAcknowledgedTasks()
public int getNumberOfNonAcknowledgedOperatorCoordinators()
public CheckpointPlan getCheckpointPlan()
public int getNumberOfAcknowledgedTasks()
public Map<OperatorID,OperatorState> getOperatorStates()
public List<MasterState> getMasterStates()
public boolean isFullyAcknowledged()
public boolean isAcknowledgedBy(ExecutionAttemptID executionAttemptId)
public boolean isDisposed()
public boolean canBeSubsumed()
public boolean setCancellerHandle(ScheduledFuture<?> cancellerHandle)
public CheckpointException getFailureCause()
public CompletableFuture<CompletedCheckpoint> getCompletionFuture()
public CompletedCheckpoint finalizeCheckpoint(CheckpointsCleaner checkpointsCleaner, Runnable postCleanup, Executor executor) throws IOException
IOException
public PendingCheckpoint.TaskAcknowledgeResult acknowledgeTask(ExecutionAttemptID executionAttemptId, TaskStateSnapshot operatorSubtaskStates, CheckpointMetrics metrics)
executionAttemptId
- of the acknowledged taskoperatorSubtaskStates
- of the acknowledged taskmetrics
- Checkpoint metrics for the statspublic PendingCheckpoint.TaskAcknowledgeResult acknowledgeCoordinatorState(OperatorInfo coordinatorInfo, @Nullable ByteStreamStateHandle stateHandle)
public void acknowledgeMasterState(String identifier, @Nullable MasterState state)
identifier
- The identifier of the master statestate
- The state to acknowledgepublic void abort(CheckpointFailureReason reason, @Nullable Throwable cause, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup, Executor executor, CheckpointStatsTracker statsTracker)
public Checkpoint.DiscardObject markAsDiscarded()
Checkpoint
Checkpoint.DiscardObject.discard()
method and should be called from the
CheckpointCoordinator
(under the lock) while Checkpoint.DiscardObject.discard()
can be
called from any thread/place.markAsDiscarded
in interface Checkpoint
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.