Uses of Interface
org.apache.flink.runtime.state.StateSnapshotContext
-
-
Uses of StateSnapshotContext in org.apache.flink.connector.file.sink.compactor.operator
Methods in org.apache.flink.connector.file.sink.compactor.operator with parameters of type StateSnapshotContext Modifier and Type Method Description void
CompactCoordinator. snapshotState(StateSnapshotContext context)
void
CompactorOperator. snapshotState(StateSnapshotContext context)
void
CompactorOperatorStateHandler. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.connector.file.table.stream
Methods in org.apache.flink.connector.file.table.stream with parameters of type StateSnapshotContext Modifier and Type Method Description void
AbstractStreamingWriter. snapshotState(StateSnapshotContext context)
void
PartitionCommitter. snapshotState(StateSnapshotContext context)
void
StreamingFileWriter. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.connector.file.table.stream.compact
Methods in org.apache.flink.connector.file.table.stream.compact with parameters of type StateSnapshotContext Modifier and Type Method Description void
CompactCoordinator. snapshotState(StateSnapshotContext context)
void
CompactOperator. snapshotState(StateSnapshotContext context)
-
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.connector.sink2
Methods in org.apache.flink.streaming.api.connector.sink2 with parameters of type StateSnapshotContext Modifier and Type Method Description void
GlobalCommitterOperator. snapshotState(StateSnapshotContext context)
-
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.api.operators.async
Methods in org.apache.flink.streaming.api.operators.async with parameters of type StateSnapshotContext Modifier and Type Method Description void
AsyncWaitOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.streaming.runtime.operators
Methods in org.apache.flink.streaming.runtime.operators with parameters of type StateSnapshotContext Modifier and Type Method Description void
GenericWriteAheadSink. 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, Function userFunction)
-
Uses of StateSnapshotContext in org.apache.flink.table.runtime.operators.sort
Methods in org.apache.flink.table.runtime.operators.sort with parameters of type StateSnapshotContext Modifier and Type Method Description void
StreamSortOperator. snapshotState(StateSnapshotContext context)
-
Uses of StateSnapshotContext in org.apache.flink.table.runtime.operators.window.tvf.common
Methods in org.apache.flink.table.runtime.operators.window.tvf.common with parameters of type StateSnapshotContext Modifier and Type Method Description void
WindowAggOperator. snapshotState(StateSnapshotContext context)
-