public class PendingCheckpoint extends Object
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 |
---|---|
static class |
PendingCheckpoint.TaskAcknowledgeResult
Result of the
acknowledgedTasks method. |
Constructor and Description |
---|
PendingCheckpoint(JobID jobId,
long checkpointId,
long checkpointTimestamp,
Map<ExecutionAttemptID,ExecutionVertex> verticesToConfirm,
CheckpointProperties props,
CheckpointStorageLocation targetLocation,
Executor executor) |
Modifier and Type | Method and Description |
---|---|
void |
abortDeclined() |
void |
abortError(Throwable cause)
Aborts the pending checkpoint due to an error.
|
void |
abortExpired()
Aborts a checkpoint because it expired (took too long).
|
void |
abortSubsumed()
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
|
PendingCheckpoint.TaskAcknowledgeResult |
acknowledgeTask(ExecutionAttemptID executionAttemptId,
TaskStateSnapshot operatorSubtaskStates,
CheckpointMetrics metrics)
Acknowledges the task with the given execution attempt id and the given subtask state.
|
void |
addMasterState(MasterState state)
Adds a master state (state generated on the checkpoint coordinator) to
the pending checkpoint.
|
boolean |
canBeSubsumed()
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless
of newer checkpoints in progress.
|
CompletedCheckpoint |
finalizeCheckpoint() |
long |
getCheckpointId() |
long |
getCheckpointTimestamp() |
CompletableFuture<CompletedCheckpoint> |
getCompletionFuture()
Returns the completion future.
|
JobID |
getJobId() |
int |
getNumberOfAcknowledgedTasks() |
int |
getNumberOfNonAcknowledgedTasks() |
Map<OperatorID,OperatorState> |
getOperatorStates() |
boolean |
isAcknowledgedBy(ExecutionAttemptID executionAttemptId) |
boolean |
isDiscarded() |
boolean |
isFullyAcknowledged() |
boolean |
setCancellerHandle(ScheduledFuture<?> cancellerHandle)
Sets the handle for the canceller to this pending checkpoint.
|
String |
toString() |
public PendingCheckpoint(JobID jobId, long checkpointId, long checkpointTimestamp, Map<ExecutionAttemptID,ExecutionVertex> verticesToConfirm, CheckpointProperties props, CheckpointStorageLocation targetLocation, Executor executor)
public JobID getJobId()
public long getCheckpointId()
public long getCheckpointTimestamp()
public int getNumberOfNonAcknowledgedTasks()
public int getNumberOfAcknowledgedTasks()
public Map<OperatorID,OperatorState> getOperatorStates()
public boolean isFullyAcknowledged()
public boolean isAcknowledgedBy(ExecutionAttemptID executionAttemptId)
public boolean isDiscarded()
public boolean canBeSubsumed()
public boolean setCancellerHandle(ScheduledFuture<?> cancellerHandle)
public CompletableFuture<CompletedCheckpoint> getCompletionFuture()
public CompletedCheckpoint finalizeCheckpoint() 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 void addMasterState(MasterState state)
state
- The state to addpublic void abortExpired()
public void abortSubsumed()
public void abortDeclined()
public void abortError(@Nonnull Throwable cause)
cause
- The error's exception.Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.