Uses of Interface
org.apache.flink.runtime.state.StateSnapshotContext
-
-
Uses of StateSnapshotContext in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators with parameters of type StateSnapshotContext Modifier and Type Method Description void
AbstractAsyncStateUdfStreamOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement StateSnapshotContext Modifier and Type Class Description class
StateSnapshotContextSynchronousImpl
This class is a default implementation for StateSnapshotContext. -
Uses of StateSnapshotContext in org.apache.flink.streaming.api.functions.source
Methods in org.apache.flink.streaming.api.functions.source with parameters of type StateSnapshotContext Modifier and Type Method Description void
ContinuousFileReaderOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators with parameters of type StateSnapshotContext Modifier and Type Method Description void
AbstractStreamOperator. snapshotState(StateSnapshotContext context)
Stream operators with state, which want to participate in a snapshot need to override this hook method.void
AbstractStreamOperatorV2. snapshotState(StateSnapshotContext context)
Stream operators with state, which want to participate in a snapshot need to override this hook method.void
AbstractUdfStreamOperator. snapshotState(StateSnapshotContext context)
void
SourceOperator. snapshotState(StateSnapshotContext context)
void
StreamOperatorStateHandler.CheckpointedStreamOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.streaming.runtime.operators.sink
Methods in org.apache.flink.streaming.runtime.operators.sink with parameters of type StateSnapshotContext Modifier and Type Method Description void
GlobalCommitterOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.streaming.util.functions
Methods in org.apache.flink.streaming.util.functions with parameters of type StateSnapshotContext Modifier and Type Method Description static void
StreamingFunctionUtils. snapshotFunctionState(StateSnapshotContext context, OperatorStateBackend backend, org.apache.flink.api.common.functions.Function userFunction)
-