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 voidAbstractAsyncStateUdfStreamOperator. 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 classStateSnapshotContextSynchronousImplThis 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 voidContinuousFileReaderOperator. 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 voidAbstractStreamOperator. snapshotState(StateSnapshotContext context)Stream operators with state, which want to participate in a snapshot need to override this hook method.voidAbstractStreamOperatorV2. snapshotState(StateSnapshotContext context)Stream operators with state, which want to participate in a snapshot need to override this hook method.voidAbstractUdfStreamOperator. snapshotState(StateSnapshotContext context)voidSourceOperator. snapshotState(StateSnapshotContext context)voidStreamOperatorStateHandler.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 voidGlobalCommitterOperator. 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 voidStreamingFunctionUtils. snapshotFunctionState(StateSnapshotContext context, OperatorStateBackend backend, org.apache.flink.api.common.functions.Function userFunction)
-