Uses of Interface
org.apache.flink.runtime.state.CheckpointStorage
-
-
Uses of CheckpointStorage in org.apache.flink.runtime.checkpoint
Methods in org.apache.flink.runtime.checkpoint that return CheckpointStorage Modifier and Type Method Description static CheckpointStorage
Checkpoints. loadCheckpointStorage(org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)
Methods in org.apache.flink.runtime.checkpoint with parameters of type CheckpointStorage Modifier and Type Method Description static void
Checkpoints. disposeSavepoint(String pointer, CheckpointStorage checkpointStorage, ClassLoader classLoader)
Constructors in org.apache.flink.runtime.checkpoint with parameters of type CheckpointStorage Constructor Description CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, CheckpointStatsTracker statsTracker)
CheckpointCoordinator(org.apache.flink.api.common.JobID job, CheckpointCoordinatorConfiguration chkConfig, Collection<OperatorCoordinatorCheckpointContext> coordinatorsToCheckpoint, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore completedCheckpointStore, CheckpointStorage checkpointStorage, Executor executor, CheckpointsCleaner checkpointsCleaner, org.apache.flink.util.concurrent.ScheduledExecutor timer, CheckpointFailureManager failureManager, CheckpointPlanCalculator checkpointPlanCalculator, org.apache.flink.util.clock.Clock clock, CheckpointStatsTracker statsTracker, BiFunction<Set<ExecutionJobVertex>,Map<OperatorID,OperatorState>,VertexFinishedStateChecker> vertexFinishedStateCheckerFactory)
-
Uses of CheckpointStorage in org.apache.flink.runtime.executiongraph
Methods in org.apache.flink.runtime.executiongraph with parameters of type CheckpointStorage Modifier and Type Method Description void
DefaultExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorageName)
void
ExecutionGraph. enableCheckpointing(CheckpointCoordinatorConfiguration chkConfig, List<MasterTriggerRestoreHook<?>> masterHooks, CheckpointIDCounter checkpointIDCounter, CompletedCheckpointStore checkpointStore, StateBackend checkpointStateBackend, CheckpointStorage checkpointStorage, CheckpointStatsTracker statsTracker, CheckpointsCleaner checkpointsCleaner, String changelogStorage)
-
Uses of CheckpointStorage in org.apache.flink.runtime.jobgraph.tasks
Methods in org.apache.flink.runtime.jobgraph.tasks that return types with arguments of type CheckpointStorage Modifier and Type Method Description org.apache.flink.util.SerializedValue<CheckpointStorage>
JobCheckpointingSettings. getDefaultCheckpointStorage()
-
Uses of CheckpointStorage in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state with type parameters of type CheckpointStorage Modifier and Type Interface Description interface
CheckpointStorageFactory<T extends CheckpointStorage>
A factory to create a specificCheckpointStorage
.Subinterfaces of CheckpointStorage in org.apache.flink.runtime.state Modifier and Type Interface Description interface
ConfigurableCheckpointStorage
An interface for checkpoint storage types that pick up additional parameters from a configuration.Methods in org.apache.flink.runtime.state that return CheckpointStorage Modifier and Type Method Description CheckpointStorage
ConfigurableCheckpointStorage. configure(org.apache.flink.configuration.ReadableConfig config, ClassLoader classLoader)
Creates a variant of the checkpoint storage that applies additional configuration parameters.static CheckpointStorage
CheckpointStorageLoader. load(CheckpointStorage fromApplication, StateBackend configuredStateBackend, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)
Loads the configuredCheckpointStorage
for the job based on the following precedent rules:Methods in org.apache.flink.runtime.state that return types with arguments of type CheckpointStorage Modifier and Type Method Description static Optional<CheckpointStorage>
CheckpointStorageLoader. fromConfig(org.apache.flink.configuration.ReadableConfig config, ClassLoader classLoader, org.slf4j.Logger logger)
Loads the checkpoint storage from the configuration, from the parameter 'execution.checkpointing.storage', as defined inCheckpointingOptions.CHECKPOINT_STORAGE
.Methods in org.apache.flink.runtime.state with parameters of type CheckpointStorage Modifier and Type Method Description static CheckpointStorage
CheckpointStorageLoader. load(CheckpointStorage fromApplication, StateBackend configuredStateBackend, org.apache.flink.configuration.Configuration jobConfig, org.apache.flink.configuration.Configuration clusterConfig, ClassLoader classLoader, org.slf4j.Logger logger)
Loads the configuredCheckpointStorage
for the job based on the following precedent rules: -
Uses of CheckpointStorage in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement CheckpointStorage Modifier and Type Class Description class
AbstractFileStateBackend
Deprecated.State backends should no longer implementCheckpointStorage
functionality. -
Uses of CheckpointStorage in org.apache.flink.runtime.state.storage
Classes in org.apache.flink.runtime.state.storage that implement CheckpointStorage Modifier and Type Class Description class
FileSystemCheckpointStorage
FileSystemCheckpointStorage
checkpoints state as files to a file system.class
JobManagerCheckpointStorage
TheCheckpointStorage
checkpoints state directly to the JobManager's memory (hence the name), but savepoints will be persisted to a file system. -
Uses of CheckpointStorage in org.apache.flink.streaming.api.graph
Methods in org.apache.flink.streaming.api.graph that return CheckpointStorage Modifier and Type Method Description CheckpointStorage
StreamConfig. getCheckpointStorage(ClassLoader cl)
Methods in org.apache.flink.streaming.api.graph with parameters of type CheckpointStorage Modifier and Type Method Description void
StreamConfig. setCheckpointStorage(CheckpointStorage storage)
void
StreamGraph. setCheckpointStorage(CheckpointStorage checkpointStorage)
Method parameters in org.apache.flink.streaming.api.graph with type arguments of type CheckpointStorage Modifier and Type Method Description void
StreamConfig. setSerializedCheckpointStorage(org.apache.flink.util.SerializedValue<CheckpointStorage> serializedCheckpointStorage)
-
Uses of CheckpointStorage in org.apache.flink.streaming.api.operators.sorted.state
Classes in org.apache.flink.streaming.api.operators.sorted.state that implement CheckpointStorage Modifier and Type Class Description class
BatchExecutionCheckpointStorage
A simpleCheckpointStorage
which is used in a BATCH style execution. -
Uses of CheckpointStorage in org.apache.flink.streaming.runtime.tasks
Fields in org.apache.flink.streaming.runtime.tasks declared as CheckpointStorage Modifier and Type Field Description protected CheckpointStorage
StreamTask. checkpointStorage
Our checkpoint storage.
-