Uses of Interface
org.apache.flink.runtime.state.FullSnapshotResources
-
Packages that use FullSnapshotResources Package Description org.apache.flink.runtime.state org.apache.flink.state.rocksdb.snapshot org.apache.flink.streaming.api.operators -
-
Uses of FullSnapshotResources in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state that return FullSnapshotResources Modifier and Type Method Description FullSnapshotResources<K>
SavepointResources. getSnapshotResources()
FullSnapshotResources<K>
SavepointSnapshotStrategy. syncPrepareResources(long checkpointId)
Methods in org.apache.flink.runtime.state with parameters of type FullSnapshotResources Modifier and Type Method Description SnapshotStrategy.SnapshotResultSupplier<KeyedStateHandle>
SavepointSnapshotStrategy. asyncSnapshot(FullSnapshotResources<K> savepointResources, long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Constructors in org.apache.flink.runtime.state with parameters of type FullSnapshotResources Constructor Description FullSnapshotAsyncWriter(SnapshotType snapshotType, SupplierWithException<CheckpointStreamWithResultProvider,Exception> checkpointStreamSupplier, FullSnapshotResources<K> snapshotResources)
SavepointResources(FullSnapshotResources<K> snapshotResources, SnapshotExecutionType preferredSnapshotExecutionType)
SavepointSnapshotStrategy(FullSnapshotResources<K> savepointResources)
Creates aSavepointSnapshotStrategy
that writes a savepoint from the givenFullSnapshotResources
. -
Uses of FullSnapshotResources in org.apache.flink.state.rocksdb.snapshot
Classes in org.apache.flink.state.rocksdb.snapshot that implement FullSnapshotResources Modifier and Type Class Description class
RocksDBFullSnapshotResources<K>
AFullSnapshotResources
for the RocksDB backend. -
Uses of FullSnapshotResources in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type FullSnapshotResources Modifier and Type Method Description static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>>
StreamOperatorStateHandler. prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend, CloseableRegistry closeableRegistry)
-