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 CompletedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)Adds aCompletedCheckpointinstance to the list of completed checkpoints.CompletedCheckpointDeactivatedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)CompletedCheckpointDefaultCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)Synchronously writes the new checkpoints to state handle store and asynchronously removes older ones.CompletedCheckpointEmbeddedCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)CompletedCheckpointStandaloneCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)CompletedCheckpointPendingCheckpoint. finalizeCheckpoint(CheckpointsCleaner checkpointsCleaner, Runnable postCleanup, Executor executor)default CompletedCheckpointCompletedCheckpointStore. getLatestCheckpoint()Returns the latestCompletedCheckpointinstance ornullif none was added.static CompletedCheckpointCheckpoints. 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 allCompletedCheckpointinstances.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 checkpointsfrom 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 CompletedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)Adds aCompletedCheckpointinstance to the list of completed checkpoints.CompletedCheckpointDeactivatedCheckpointCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)CompletedCheckpointDefaultCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)Synchronously writes the new checkpoints to state handle store and asynchronously removes older ones.CompletedCheckpointEmbeddedCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)CompletedCheckpointStandaloneCompletedCheckpointStore. addCheckpointAndSubsumeOldestOne(CompletedCheckpoint checkpoint, CheckpointsCleaner checkpointsCleaner, Runnable postCleanup)voidCheckpointsCleaner. addSubsumedCheckpoint(CompletedCheckpoint completedCheckpoint)Add one subsumed checkpoint to CheckpointsCleaner, the subsumed checkpoint would be discarded atCheckpointsCleaner.cleanSubsumedCheckpoints(long, Set, Runnable, Executor).voidCheckpointsCleaner. 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 booleanCompletedCheckpoint. 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 checkpointsfrom anexternal store.protected voidAbstractCompleteCheckpointStore. 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 aDefaultCompletedCheckpointStoreinstance.DefaultCompletedCheckpointStore(int maxNumberOfCheckpointsToRetain, StateHandleStore<CompletedCheckpoint,R> stateHandleStore, CheckpointStoreUtil completedCheckpointStoreUtil, Collection<CompletedCheckpoint> completedCheckpoints, SharedStateRegistry sharedStateRegistry, Executor executor)Creates aDefaultCompletedCheckpointStoreinstance.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.adaptive.allocator
Methods in org.apache.flink.runtime.scheduler.adaptive.allocator with parameters of type CompletedCheckpoint Modifier and Type Method Description static JobAllocationsInformationJobAllocationsInformation. fromGraphAndState(ExecutionGraph graph, CompletedCheckpoint latestCheckpoint)static StateSizeEstimatesStateSizeEstimates. fromGraphAndState(ExecutionGraph executionGraph, CompletedCheckpoint latestCheckpoint) -
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 voidStopWithSavepointTerminationHandler. handleSavepointCreation(CompletedCheckpoint completedSavepoint, Throwable throwable)Handles the result of aCompletableFutureholding aCompletedCheckpoint.voidStopWithSavepointTerminationHandlerImpl. 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 passedCompletableFutureinstances 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 voidSharedStateRegistry. registerAllAfterRestored(CompletedCheckpoint checkpoint, org.apache.flink.core.execution.RecoveryClaimMode mode)Set the lowest checkpoint ID below which no state is discarded, inclusive.voidSharedStateRegistryImpl. 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 SharedStateRegistrySharedStateRegistryFactory. create(Executor deleteExecutor, Collection<CompletedCheckpoint> checkpoints, org.apache.flink.core.execution.RecoveryClaimMode recoveryClaimMode)Factory method forSharedStateRegistry.
-