Uses of Interface
org.apache.flink.runtime.state.CheckpointableKeyedStateBackend
-
Packages that use CheckpointableKeyedStateBackend Package Description org.apache.flink.runtime.state 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 CheckpointableKeyedStateBackend in org.apache.flink.runtime.state
Classes in org.apache.flink.runtime.state that implement CheckpointableKeyedStateBackend Modifier and Type Class Description class
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.Methods in org.apache.flink.runtime.state that return CheckpointableKeyedStateBackend Modifier and Type Method Description <K> CheckpointableKeyedStateBackend<K>
StateBackend. createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K> parameters)
Creates a newCheckpointableKeyedStateBackend
that is responsible for holding keyed state and checkpointing it. -
Uses of CheckpointableKeyedStateBackend in org.apache.flink.runtime.state.heap
Classes in org.apache.flink.runtime.state.heap that implement CheckpointableKeyedStateBackend Modifier and Type Class Description class
HeapKeyedStateBackend<K>
AAbstractKeyedStateBackend
that keeps state on the Java Heap and will serialize state to streams provided by aCheckpointStreamFactory
upon checkpointing. -
Uses of CheckpointableKeyedStateBackend in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor that return CheckpointableKeyedStateBackend Modifier and Type Method Description CheckpointableKeyedStateBackend<K>
AsyncKeyedStateBackendAdaptor. getKeyedStateBackend()
Constructors in org.apache.flink.runtime.state.v2.adaptor with parameters of type CheckpointableKeyedStateBackend Constructor Description AsyncKeyedStateBackendAdaptor(CheckpointableKeyedStateBackend<K> keyedStateBackend)
-
Uses of CheckpointableKeyedStateBackend in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return CheckpointableKeyedStateBackend Modifier and Type Method Description CheckpointableKeyedStateBackend<?>
StreamOperatorStateContext. keyedStateBackend()
Returns the keyed state backend for the stream operator.Methods in org.apache.flink.streaming.api.operators with parameters of type CheckpointableKeyedStateBackend Modifier and Type Method Description static SnapshotStrategyRunner<KeyedStateHandle,? extends FullSnapshotResources<?>>
StreamOperatorStateHandler. prepareCanonicalSavepoint(CheckpointableKeyedStateBackend<?> keyedStateBackend, org.apache.flink.core.fs.CloseableRegistry closeableRegistry)
-
Uses of CheckpointableKeyedStateBackend in org.apache.flink.streaming.api.operators.sorted.state
Classes in org.apache.flink.streaming.api.operators.sorted.state that implement CheckpointableKeyedStateBackend Modifier and Type Class Description class
BatchExecutionKeyedStateBackend<K>
ACheckpointableKeyedStateBackend
which keeps values for a single key at a time.Methods in org.apache.flink.streaming.api.operators.sorted.state that return CheckpointableKeyedStateBackend Modifier and Type Method Description <K> CheckpointableKeyedStateBackend<K>
BatchExecutionStateBackend. createKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K> parameters)
-