Uses of Class
org.apache.flink.runtime.state.SnapshotStrategyRunner
-
Packages that use SnapshotStrategyRunner Package Description org.apache.flink.runtime.state org.apache.flink.streaming.api.operators -
-
Uses of SnapshotStrategyRunner in org.apache.flink.runtime.state
Constructors in org.apache.flink.runtime.state with parameters of type SnapshotStrategyRunner Constructor Description DefaultOperatorStateBackend(org.apache.flink.api.common.ExecutionConfig executionConfig, org.apache.flink.core.fs.CloseableRegistry closeStreamOnCancelRegistry, Map<String,PartitionableListState<?>> registeredOperatorStates, Map<String,BackendWritableBroadcastState<?,?>> registeredBroadcastStates, Map<String,PartitionableListState<?>> accessedStatesByName, Map<String,BackendWritableBroadcastState<?,?>> accessedBroadcastStatesByName, SnapshotStrategyRunner<OperatorStateHandle,?> snapshotStrategyRunner)
-
Uses of SnapshotStrategyRunner in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return SnapshotStrategyRunner Modifier and Type Method Description static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>>
StreamOperatorStateHandler. prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend, org.apache.flink.core.fs.CloseableRegistry closeableRegistry)
-