Uses of Interface
org.apache.flink.runtime.state.KeyedStateBackend
-
Packages that use KeyedStateBackend 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.ttl org.apache.flink.streaming.api.operators org.apache.flink.streaming.api.operators.sorted.state org.apache.flink.streaming.runtime.operators.windowing -
-
Uses of KeyedStateBackend in org.apache.flink.runtime.state
Subinterfaces of KeyedStateBackend in org.apache.flink.runtime.state Modifier and Type Interface Description interface
CheckpointableKeyedStateBackend<K>
Interface that combines both, theKeyedStateBackend
interface, which encapsulates methods responsible for keyed state management and theSnapshotable
which tells the system how to snapshot the underlying state.interface
TestableKeyedStateBackend<K>
A keyed state backend interface for internal testing purpose.Classes in org.apache.flink.runtime.state that implement KeyedStateBackend Modifier and Type Class Description class
AbstractKeyedStateBackend<K>
Base implementation of KeyedStateBackend.Fields in org.apache.flink.runtime.state declared as KeyedStateBackend Modifier and Type Field Description protected KeyedStateBackend<?>
DefaultKeyedStateStore. keyedStateBackend
Methods in org.apache.flink.runtime.state that return KeyedStateBackend Modifier and Type Method Description default KeyedStateBackend<K>
TestableKeyedStateBackend. getDelegatedKeyedStateBackend(boolean recursive)
Constructors in org.apache.flink.runtime.state with parameters of type KeyedStateBackend Constructor Description DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, AsyncKeyedStateBackend<?> asyncKeyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
Uses of KeyedStateBackend in org.apache.flink.runtime.state.heap
Classes in org.apache.flink.runtime.state.heap that implement KeyedStateBackend 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 KeyedStateBackend in org.apache.flink.runtime.state.ttl
Methods in org.apache.flink.runtime.state.ttl with parameters of type KeyedStateBackend Modifier and Type Method Description static <K,N,SV,TTLSV,S extends org.apache.flink.api.common.state.State,IS extends S>
ISTtlStateFactory. createStateAndWrapWithTtlIfEnabled(org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,SV> stateDesc, KeyedStateBackend<K> stateBackend, TtlTimeProvider timeProvider)
-
Uses of KeyedStateBackend in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return KeyedStateBackend Modifier and Type Method Description <K> KeyedStateBackend<K>
AbstractStreamOperator. getKeyedStateBackend()
<K> KeyedStateBackend<K>
AbstractStreamOperatorV2. getKeyedStateBackend()
<K> KeyedStateBackend<K>
StreamOperatorStateHandler. getKeyedStateBackend()
-
Uses of KeyedStateBackend in org.apache.flink.streaming.api.operators.sorted.state
Classes in org.apache.flink.streaming.api.operators.sorted.state that implement KeyedStateBackend Modifier and Type Class Description class
BatchExecutionKeyedStateBackend<K>
ACheckpointableKeyedStateBackend
which keeps values for a single key at a time. -
Uses of KeyedStateBackend in org.apache.flink.streaming.runtime.operators.windowing
Constructors in org.apache.flink.streaming.runtime.operators.windowing with parameters of type KeyedStateBackend Constructor Description AbstractPerWindowStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig)
MergingWindowStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig)
PerWindowStateStore(KeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig)
-