Package org.apache.flink.runtime.state.v2
-
Interface Summary Interface Description KeyedStateStoreV2 This interface contains methods for registeringState
. -
Class Summary Class Description AbstractAggregatingState<K,N,IN,ACC,OUT> The default implementation ofAggregatingState
, which delegates all async requests toStateRequestHandler
.AbstractKeyedState<K,N,V> TheAbstractKeyedState
is the root of the abstract state implementation hierarchy, similar to theState
being the root of the public API state hierarchy.AbstractListState<K,N,V> A default implementation ofListState
which delegates all async requests toStateRequestHandler
.AbstractMapState<K,N,UK,V> A default implementation ofMapState
which delegates all async requests toStateRequestHandler
.AbstractReducingState<K,N,V> A default implementation ofReducingState
which delegates all async requests toStateRequestHandler
.AbstractValueState<K,N,V> A default implementation ofValueState
which delegates all async requests toAsyncExecutionController
.AggregatingStateDescriptor<IN,ACC,OUT> AStateDescriptor
forAggregatingState
.DefaultKeyedStateStoreV2 Default implementation of KeyedStateStoreV2.ListStateDescriptor<T> StateDescriptor
forListState
.MapStateDescriptor<UK,UV> StateDescriptor
forMapState
.ReducingStateDescriptor<T> RegisteredKeyValueStateBackendMetaInfo<N,S> Compound meta information for a registered state in a keyed state backend.StateDescriptor<T> Base class for state descriptors.StateDescriptorUtils Utilities for transformingStateDescriptor
toStateDescriptor
.SyncIteratorWrapper<T> ValueStateDescriptor<T> -
Enum Summary Enum Description StateDescriptor.Type An enumeration of the types of supported states.