Uses of Class
org.apache.flink.runtime.state.SnapshotResult
-
Packages that use SnapshotResult Package Description org.apache.flink.runtime.state org.apache.flink.runtime.state.changelog 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.v2.adaptor org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of SnapshotResult in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state with type parameters of type SnapshotResult Modifier and Type Field Description protected RunnableFuture<SnapshotResult<KeyedStateHandle>>
StateSnapshotContextSynchronousImpl. keyedStateCheckpointClosingFuture
protected RunnableFuture<SnapshotResult<OperatorStateHandle>>
StateSnapshotContextSynchronousImpl. operatorStateCheckpointClosingFuture
Methods in org.apache.flink.runtime.state that return SnapshotResult Modifier and Type Method Description SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider. closeAndFinalizeCheckpointStreamResult()
Closes the stream ans returns a snapshot result with the stream handle(s).SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider.PrimaryAndSecondaryStream. closeAndFinalizeCheckpointStreamResult()
SnapshotResult<StreamStateHandle>
CheckpointStreamWithResultProvider.PrimaryStreamOnly. closeAndFinalizeCheckpointStreamResult()
static <T extends StateObject>
SnapshotResult<T>SnapshotResult. empty()
SnapshotResult<KeyedStateHandle>
FullSnapshotAsyncWriter. get(org.apache.flink.core.fs.CloseableRegistry snapshotCloseableRegistry)
SnapshotResult<S>
SnapshotStrategy.SnapshotResultSupplier. get(org.apache.flink.core.fs.CloseableRegistry snapshotCloseableRegistry)
Performs the asynchronous part of a checkpoint and returns the snapshot result.static <T extends StateObject>
SnapshotResult<T>SnapshotResult. of(T jobManagerState)
static SnapshotResult<KeyedStateHandle>
CheckpointStreamWithResultProvider. toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult, KeyGroupRangeOffsets keyGroupRangeOffsets, CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes aSnapshotResult
and aKeyGroupRangeOffsets
and creates aSnapshotResult
by combining the key groups offsets with all the present stream state handles.static <T extends StateObject>
SnapshotResult<T>SnapshotResult. withLocalState(T jobManagerState, T localState)
Methods in org.apache.flink.runtime.state that return types with arguments of type SnapshotResult Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
StateSnapshotContextSynchronousImpl. getKeyedStateStreamFuture()
RunnableFuture<SnapshotResult<OperatorStateHandle>>
StateSnapshotContextSynchronousImpl. getOperatorStateStreamFuture()
RunnableFuture<SnapshotResult<OperatorStateHandle>>
DefaultOperatorStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
RunnableFuture<SnapshotResult<T>>
SnapshotStrategyRunner. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
Methods in org.apache.flink.runtime.state with parameters of type SnapshotResult Modifier and Type Method Description static SnapshotResult<KeyedStateHandle>
CheckpointStreamWithResultProvider. toKeyedStateHandleSnapshotResult(SnapshotResult<StreamStateHandle> snapshotResult, KeyGroupRangeOffsets keyGroupRangeOffsets, CheckpointStreamWithResultProvider.KeyedStateHandleFactory stateHandleFactory)
Helper method that takes aSnapshotResult
and aKeyGroupRangeOffsets
and creates aSnapshotResult
by combining the key groups offsets with all the present stream state handles. -
Uses of SnapshotResult in org.apache.flink.runtime.state.changelog
Methods in org.apache.flink.runtime.state.changelog that return types with arguments of type SnapshotResult Modifier and Type Method Description CompletableFuture<SnapshotResult<Handle>>
StateChangelogWriter. persist(SequenceNumber from, long checkpointId)
Durably persist previouslyappended
data starting from the providedSequenceNumber
and up to the latest change added. -
Uses of SnapshotResult in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap that return types with arguments of type SnapshotResult Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
HeapKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of SnapshotResult in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return types with arguments of type SnapshotResult Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
AsyncKeyedStateBackendAdaptor. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-
Uses of SnapshotResult in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return types with arguments of type SnapshotResult Modifier and Type Method Description Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>>
OperatorSnapshotFutures. getInputChannelStateFuture()
RunnableFuture<SnapshotResult<KeyedStateHandle>>
OperatorSnapshotFutures. getKeyedStateManagedFuture()
RunnableFuture<SnapshotResult<KeyedStateHandle>>
OperatorSnapshotFutures. getKeyedStateRawFuture()
RunnableFuture<SnapshotResult<OperatorStateHandle>>
OperatorSnapshotFutures. getOperatorStateManagedFuture()
RunnableFuture<SnapshotResult<OperatorStateHandle>>
OperatorSnapshotFutures. getOperatorStateRawFuture()
Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>>
OperatorSnapshotFutures. getResultSubpartitionStateFuture()
Method parameters in org.apache.flink.streaming.api.operators with type arguments of type SnapshotResult Modifier and Type Method Description void
OperatorSnapshotFutures. setInputChannelStateFuture(Future<SnapshotResult<StateObjectCollection<InputChannelStateHandle>>> inputChannelStateFuture)
void
OperatorSnapshotFutures. setKeyedStateManagedFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateManagedFuture)
void
OperatorSnapshotFutures. setKeyedStateRawFuture(RunnableFuture<SnapshotResult<KeyedStateHandle>> keyedStateRawFuture)
void
OperatorSnapshotFutures. setOperatorStateManagedFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateManagedFuture)
void
OperatorSnapshotFutures. setOperatorStateRawFuture(RunnableFuture<SnapshotResult<OperatorStateHandle>> operatorStateRawFuture)
void
OperatorSnapshotFutures. setResultSubpartitionStateFuture(Future<SnapshotResult<StateObjectCollection<ResultSubpartitionStateHandle>>> resultSubpartitionStateFuture)
-
Uses of SnapshotResult in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state that return types with arguments of type SnapshotResult Modifier and Type Method Description RunnableFuture<SnapshotResult<KeyedStateHandle>>
BatchExecutionKeyedStateBackend. snapshot(long checkpointId, long timestamp, CheckpointStreamFactory streamFactory, CheckpointOptions checkpointOptions)
-