Uses of Interface
org.apache.flink.runtime.state.v2.internal.InternalKeyedState
-
-
Uses of InternalKeyedState in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with type parameters of type InternalKeyedState Modifier and Type Method Description <N,S extends InternalKeyedState,SV>
SAsyncKeyedStateBackend. createStateInternal(N defaultNamespace, TypeSerializer<N> namespaceSerializer, StateDescriptor<SV> stateDesc)
Creates and returns a new state for internal usage. -
Uses of InternalKeyedState in org.apache.flink.runtime.state.v2
Classes in org.apache.flink.runtime.state.v2 that implement InternalKeyedState Modifier and Type Class Description class
AbstractAggregatingState<K,N,IN,ACC,OUT>
The default implementation ofAggregatingState
, which delegates all async requests toStateRequestHandler
.class
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.class
AbstractListState<K,N,V>
A default implementation ofListState
which delegates all async requests toStateRequestHandler
.class
AbstractMapState<K,N,UK,V>
A default implementation ofMapState
which delegates all async requests toStateRequestHandler
.class
AbstractReducingState<K,N,V>
A default implementation ofReducingState
which delegates all async requests toStateRequestHandler
.class
AbstractValueState<K,N,V>
A default implementation ofValueState
which delegates all async requests toAsyncExecutionController
. -
Uses of InternalKeyedState in org.apache.flink.runtime.state.v2.adaptor
Classes in org.apache.flink.runtime.state.v2.adaptor that implement InternalKeyedState Modifier and Type Class Description class
AggregatingStateAdaptor<K,N,IN,ACC,OUT>
An adaptor that transformsInternalAggregatingState
intoInternalAggregatingState
.class
ListStateAdaptor<K,N,V>
An adaptor that transformsInternalListState
intoInternalListState
.class
MapStateAdaptor<K,N,UK,UV>
An adaptor that transformsInternalMapState
intoInternalMapState
.class
MergingStateAdaptor<K,N,IN,ACC,OUT,SYNCOUT>
An adaptor that transformsInternalMergingState
intoInternalMergingState
.class
ReducingStateAdaptor<K,N,V>
An adaptor that transformsInternalReducingState
intoInternalReducingState
.class
ValueStateAdaptor<K,N,V>
An adaptor that transformsInternalValueState
intoInternalValueState
.Methods in org.apache.flink.runtime.state.v2.adaptor with type parameters of type InternalKeyedState Modifier and Type Method Description <N,S extends InternalKeyedState,SV>
SAsyncKeyedStateBackendAdaptor. createStateInternal(N defaultNamespace, TypeSerializer<N> namespaceSerializer, StateDescriptor<SV> stateDesc)
-
Uses of InternalKeyedState in org.apache.flink.runtime.state.v2.internal
Subinterfaces of InternalKeyedState in org.apache.flink.runtime.state.v2.internal Modifier and Type Interface Description interface
InternalAggregatingState<K,N,IN,ACC,OUT>
This class defines the internal interface for aggregating state.interface
InternalAppendingState<K,N,IN,SV,OUT,SYNCOUT>
This class defines the internal interface for appending state.interface
InternalListState<K,N,V>
This class defines the internal interface for list state.interface
InternalMapState<K,N,UK,UV>
This class defines the internal interface for map state.interface
InternalMergingState<K,N,IN,SV,OUT,SYNCOUT>
This class defines the internal interface for merging state.interface
InternalReducingState<K,N,T>
This class defines the internal interface for reducing state.interface
InternalValueState<K,N,V>
This class defines the internal interface for value state. -
Uses of InternalKeyedState in org.apache.flink.state.forst
Classes in org.apache.flink.state.forst that implement InternalKeyedState Modifier and Type Class Description class
ForStAggregatingState<K,N,IN,ACC,OUT>
The implementation ofAggregatingState
for ForStDB.class
ForStListState<K,N,V>
TheAbstractListState
implement for ForStDB.class
ForStMapState<K,N,UK,UV>
TheAbstractMapState
implement for ForStDB.class
ForStReducingState<K,N,V>
TheAbstractReducingState
implement for ForStDB.class
ForStValueState<K,N,V>
TheAbstractValueState
implement for ForStDB.Methods in org.apache.flink.state.forst with type parameters of type InternalKeyedState Modifier and Type Method Description <N,S extends InternalKeyedState,SV>
SForStKeyedStateBackend. createStateInternal(N defaultNamespace, TypeSerializer<N> namespaceSerializer, StateDescriptor<SV> stateDesc)
-