Uses of Class
org.apache.flink.runtime.checkpoint.CompletedCheckpoint
-
-
Uses of CompletedCheckpoint in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CompletedCheckpoint Modifier and Type Method Description CompletedCheckpoint
CompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
Adds aCompletedCheckpoint
instance to the list of completed checkpoints.CompletedCheckpoint
DeactivatedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
CompletedCheckpoint
DefaultCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
Synchronously writes the new checkpoints to state handle store and asynchronously removes older ones.CompletedCheckpoint
EmbeddedCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
CompletedCheckpoint
StandaloneCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
CompletedCheckpoint
PendingCheckpoint. finalizeCheckpoint(CheckpointsCleaner checkpointsCleaner, Runnable postCleanup, Executor executor)
default CompletedCheckpoint
CompletedCheckpointStore. getLatestCheckpoint()
Returns the latestCompletedCheckpoint
instance ornull
if none was added.static CompletedCheckpoint
Checkpoints. loadAndValidateCheckpoint(org.apache.flink.api.common.JobID jobId, Map<JobVertexID,ExecutionJobVertex> tasks, CompletedCheckpointStorageLocation location, ClassLoader classLoader, boolean allowNonRestoredState, CheckpointProperties checkpointProperties)
Methods in org.apache.flink.runtime.checkpoint that return types with arguments of type CompletedCheckpoint Modifier and Type Method Description List<CompletedCheckpoint>
CompletedCheckpointStore. getAllCheckpoints()
Returns allCompletedCheckpoint
instances.List<CompletedCheckpoint>
DeactivatedCheckpointCompletedCheckpointStore. getAllCheckpoints()
List<CompletedCheckpoint>
DefaultCompletedCheckpointStore. getAllCheckpoints()
List<CompletedCheckpoint>
EmbeddedCompletedCheckpointStore. getAllCheckpoints()
List<CompletedCheckpoint>
StandaloneCompletedCheckpointStore. getAllCheckpoints()
CompletableFuture<CompletedCheckpoint>
PendingCheckpoint. getCompletionFuture()
Returns the completion future.List<CompletedCheckpoint>
CheckpointCoordinator. getSuccessfulCheckpoints()
static <R extends ResourceVersion<R>>
Collection<CompletedCheckpoint>DefaultCompletedCheckpointStoreUtils. retrieveCompletedCheckpoints(StateHandleStore<CompletedCheckpoint,R> checkpointStateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil)
Fetch allcompleted checkpoints
from anexternal store
.CompletableFuture<CompletedCheckpoint>
CheckpointCoordinator. triggerCheckpoint(boolean isPeriodic)
Triggers a new standard checkpoint and uses the given timestamp as the checkpoint timestamp.CompletableFuture<CompletedCheckpoint>
CheckpointCoordinator. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType)
Triggers one new checkpoint with the given checkpointType.CompletableFuture<CompletedCheckpoint>
CheckpointCoordinator. triggerSavepoint(String targetLocation, org.apache.flink.core.execution.SavepointFormatType formatType)
Triggers a savepoint with the given savepoint directory as a target.CompletableFuture<CompletedCheckpoint>
CheckpointCoordinator. triggerSynchronousSavepoint(boolean terminate, String targetLocation, org.apache.flink.core.execution.SavepointFormatType formatType)
Triggers a synchronous savepoint with the given savepoint directory as a target.Methods in org.apache.flink.runtime.checkpoint with parameters of type CompletedCheckpoint Modifier and Type Method Description CompletedCheckpoint
CompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
Adds aCompletedCheckpoint
instance to the list of completed checkpoints.CompletedCheckpoint
DeactivatedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
CompletedCheckpoint
DefaultCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
Synchronously writes the new checkpoints to state handle store and asynchronously removes older ones.CompletedCheckpoint
EmbeddedCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
CompletedCheckpoint
StandaloneCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)
void
CheckpointsCleaner. addSubsumedCheckpoint(CompletedCheckpoint completedCheckpoint)
Add one subsumed checkpoint to CheckpointsCleaner, the subsumed checkpoint would be discarded atCheckpointsCleaner.cleanSubsumedCheckpoints(long, Set, Runnable, Executor)
.void
CheckpointsCleaner. cleanCheckpointOnFailedStoring(CompletedCheckpoint completedCheckpoint, Executor executor)
Method parameters in org.apache.flink.runtime.checkpoint with type arguments of type CompletedCheckpoint Modifier and Type Method Description static boolean
CompletedCheckpoint. checkpointsMatch(Collection<CompletedCheckpoint> first, Collection<CompletedCheckpoint> second)
protected static Optional<Long>
AbstractCompleteCheckpointStore. findLowest(Deque<CompletedCheckpoint> unSubsumedCheckpoints)
static <R extends ResourceVersion<R>>
Collection<CompletedCheckpoint>DefaultCompletedCheckpointStoreUtils. retrieveCompletedCheckpoints(StateHandleStore<CompletedCheckpoint,R> checkpointStateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil)
Fetch allcompleted checkpoints
from anexternal store
.protected void
AbstractCompleteCheckpointStore. unregisterUnusedState(Deque<CompletedCheckpoint> unSubsumedCheckpoints)
Unregister shared states that are no longer in use.Constructor parameters in org.apache.flink.runtime.checkpoint with type arguments of type CompletedCheckpoint Constructor Description DefaultCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, StateHandleStore<CompletedCheckpoint,R> stateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil, Collection<CompletedCheckpoint> completedCheckpoints, SharedStateRegistry sharedStateRegistry, Executor executor)
Creates aDefaultCompletedCheckpointStore
instance.DefaultCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, StateHandleStore<CompletedCheckpoint,R> stateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil, Collection<CompletedCheckpoint> completedCheckpoints, SharedStateRegistry sharedStateRegistry, Executor executor)
Creates aDefaultCompletedCheckpointStore
instance.EmbeddedCompletedCheckpointStore(int maxRetainedCheckpoints, Collection<CompletedCheckpoint> initialCheckpoints, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
EmbeddedCompletedCheckpointStore(int maxRetainedCheckpoints, Collection<CompletedCheckpoint> initialCheckpoints, SharedStateRegistry sharedStateRegistry)
PendingCheckpoint(org.apache.flink.api.common.JobID jobId, long checkpointId, long checkpointTimestamp, CheckpointPlan checkpointPlan, Collection<OperatorID> operatorCoordinatorsToConfirm, Collection<String> masterStateIdentifiers, CheckpointProperties props, CompletableFuture<CompletedCheckpoint> onCompletionPromise, PendingCheckpointStats pendingCheckpointStats, CompletableFuture<Void> masterTriggerCompletionPromise)
-
Uses of CompletedCheckpoint in org.apache.flink.runtime.jobmaster
Methods in org.apache.flink.runtime.jobmaster that return types with arguments of type CompletedCheckpoint Modifier and Type Method Description CompletableFuture<CompletedCheckpoint>
JobMaster. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
CompletableFuture<CompletedCheckpoint>
JobMasterGateway. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType, Duration timeout)
Triggers taking a checkpoint of the executed job. -
Uses of CompletedCheckpoint in org.apache.flink.runtime.scheduler
Methods in org.apache.flink.runtime.scheduler that return types with arguments of type CompletedCheckpoint Modifier and Type Method Description CompletableFuture<CompletedCheckpoint>
SchedulerBase. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType)
CompletableFuture<CompletedCheckpoint>
SchedulerNG. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType)
-
Uses of CompletedCheckpoint in org.apache.flink.runtime.scheduler.adaptive
Methods in org.apache.flink.runtime.scheduler.adaptive that return types with arguments of type CompletedCheckpoint Modifier and Type Method Description CompletableFuture<CompletedCheckpoint>
AdaptiveScheduler. triggerCheckpoint(org.apache.flink.core.execution.CheckpointType checkpointType)
-
Uses of CompletedCheckpoint in org.apache.flink.runtime.scheduler.stopwithsavepoint
Methods in org.apache.flink.runtime.scheduler.stopwithsavepoint with parameters of type CompletedCheckpoint Modifier and Type Method Description void
StopWithSavepointTerminationHandler. handleSavepointCreation(CompletedCheckpoint completedSavepoint, Throwable throwable)
Handles the result of aCompletableFuture
holding aCompletedCheckpoint
.void
StopWithSavepointTerminationHandlerImpl. handleSavepointCreation(CompletedCheckpoint completedSavepoint, Throwable throwable)
Method parameters in org.apache.flink.runtime.scheduler.stopwithsavepoint with type arguments of type CompletedCheckpoint Modifier and Type Method Description CompletableFuture<String>
StopWithSavepointTerminationManager. stopWithSavepoint(CompletableFuture<CompletedCheckpoint> completedSavepointFuture, CompletableFuture<Collection<ExecutionState>> terminatedExecutionStatesFuture, org.apache.flink.runtime.concurrent.ComponentMainThreadExecutor mainThreadExecutor)
Enforces the correct completion order of the passedCompletableFuture
instances in accordance to the contract ofStopWithSavepointTerminationHandler
. -
Uses of CompletedCheckpoint in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type CompletedCheckpoint Modifier and Type Method Description void
SharedStateRegistry. registerAllAfterRestored(CompletedCheckpoint checkpoint, org.apache.flink.core.execution.RecoveryClaimMode mode)
Set the lowest checkpoint ID below which no state is discarded, inclusive.void
SharedStateRegistryImpl. registerAllAfterRestored(CompletedCheckpoint checkpoint, org.apache.flink.core.execution.RecoveryClaimMode mode)
Method parameters in org.apache.flink.runtime.state with type arguments of type CompletedCheckpoint Modifier and Type Method Description SharedStateRegistry
SharedStateRegistryFactory. create(Executor deleteExecutor, Collection<CompletedCheckpoint> checkpoints, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)
Factory method forSharedStateRegistry
.
-