Uses of Interface
org.apache.flink.runtime.state.CheckpointStreamFactory
-
Packages that use CheckpointStreamFactory Package Description org.apache.flink.runtime.state org.apache.flink.runtime.state.filesystem org.apache.flink.runtime.state.heap This package contains the classes for key/value state backends that store the state on the JVM heap as objects.org.apache.flink.runtime.state.memory org.apache.flink.runtime.state.v2.adaptor org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state org.apache.flink.streaming.runtime.tasks -
-
Uses of CheckpointStreamFactory in org.apache.flink.runtime.state
Subinterfaces of CheckpointStreamFactory in org.apache.flink.runtime.state Modifier and Type Interface Description interfaceCheckpointStorageLocationA storage location for one particular checkpoint, offering data persistent, metadata persistence, and lifecycle/cleanup methods.Methods in org.apache.flink.runtime.state that return CheckpointStreamFactory Modifier and Type Method Description CheckpointStreamFactoryCheckpointStorageWorkerView. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)Resolves a storage location reference into a CheckpointStreamFactory.Methods in org.apache.flink.runtime.state with parameters of type CheckpointStreamFactory Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>SavepointSnapshotStrategy. asyncSnapshot(FullSnapshotResources<K> savepointResources, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)SnapshotStrategy.SnapshotResultSupplier<S>SnapshotStrategy. asyncSnapshot(SR syncPartResource, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)Operation that writes a snapshot into a stream that is provided by the givenCheckpointStreamFactoryand returns a @SupplierWithExceptionthat gives a state handle to the snapshot.static CheckpointStreamWithResultProviderCheckpointStreamWithResultProvider. createDuplicatingStream(long checkpointId, CheckpointedStateScope checkpointedStateScope, CheckpointStreamFactory primaryStreamFactory, LocalSnapshotDirectoryProvider secondaryStreamDirProvider)static CheckpointStreamWithResultProviderCheckpointStreamWithResultProvider. createSimpleStream(CheckpointedStateScope checkpointedStateScope, CheckpointStreamFactory primaryStreamFactory)RunnableFuture<SnapshotResult<OperatorStateHandle>>DefaultOperatorStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)RunnableFuture<S>Snapshotable. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)Operation that writes a snapshot into a stream that is provided by the givenCheckpointStreamFactoryand returns a @RunnableFuturethat gives a state handle to the snapshot.RunnableFuture<SnapshotResult<T>>SnapshotStrategyRunner. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)Constructors in org.apache.flink.runtime.state with parameters of type CheckpointStreamFactory Constructor Description StateSnapshotContextSynchronousImpl(long checkpointId, long checkpointTimestamp, CheckpointStreamFactory streamFactory, KeyGroupRange keyGroupRange, org.apache.flink.core.fs.CloseableRegistry closableRegistry) -
Uses of CheckpointStreamFactory in org.apache.flink.runtime.state.filesystem
Classes in org.apache.flink.runtime.state.filesystem that implement CheckpointStreamFactory Modifier and Type Class Description classFsCheckpointStorageLocationA storage location for checkpoints on a file system.classFsCheckpointStreamFactoryACheckpointStreamFactorythat produces streams that write to aFileSystem.classFsMergingCheckpointStorageLocationAn implementation of checkpoint storage location for file merging checkpoints.Methods in org.apache.flink.runtime.state.filesystem that return CheckpointStreamFactory Modifier and Type Method Description CheckpointStreamFactoryFsCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)CheckpointStreamFactoryFsMergingCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference)CheckpointStreamFactoryFsMergingCheckpointStorageLocation. toNonFileMerging() -
Uses of CheckpointStreamFactory in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap with parameters of type CheckpointStreamFactory Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>HeapKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions) -
Uses of CheckpointStreamFactory in org.apache.flink.runtime.state.memory
Classes in org.apache.flink.runtime.state.memory that implement CheckpointStreamFactory Modifier and Type Class Description classMemCheckpointStreamFactoryCheckpointStreamFactorythat produces streams that write to in-memory byte arrays.classNonPersistentMetadataCheckpointStorageLocationA checkpoint storage location for theMemCheckpointStreamFactoryin case no durable persistence for metadata has been configured.classPersistentMetadataCheckpointStorageLocationA checkpoint storage location for theMemCheckpointStreamFactorywhen it durably persists the metadata in a file system.Methods in org.apache.flink.runtime.state.memory that return CheckpointStreamFactory Modifier and Type Method Description CheckpointStreamFactoryMemoryBackendCheckpointStorageAccess. resolveCheckpointStorageLocation(long checkpointId, CheckpointStorageLocationReference reference) -
Uses of CheckpointStreamFactory in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor with parameters of type CheckpointStreamFactory Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>AsyncKeyedStateBackendAdaptor. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions) -
Uses of CheckpointStreamFactory in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type CheckpointStreamFactory Modifier and Type Method Description OperatorSnapshotFuturesAbstractStreamOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)OperatorSnapshotFuturesAbstractStreamOperatorV2. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory)OperatorSnapshotFuturesStreamOperator. snapshotState(long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory storageLocation)Called to draw a state snapshot from the operator.OperatorSnapshotFuturesStreamOperatorStateHandler. snapshotState(StreamOperatorStateHandler.CheckpointedStreamOperator streamOperator, Optional<InternalTimeServiceManager<?>> timeServiceManager, String operatorName, long checkpointId, long timestamp, CheckpointOptions checkpointOptions, CheckpointStreamFactory factory, boolean isUsingCustomRawKeyedState, boolean useAsyncState) -
Uses of CheckpointStreamFactory in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type CheckpointStreamFactory Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>BatchExecutionKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions) -
Uses of CheckpointStreamFactory in org.apache.flink.streaming.runtime.tasks
-