Uses of Interface
org.apache.flink.runtime.state.internal.InternalKvState
-
Packages that use InternalKvState Package Description org.apache.flink.runtime.query 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.internal This package holds the classes of the internal state type hierarchy.org.apache.flink.runtime.state.metrics org.apache.flink.runtime.state.v2.adaptor -
-
Uses of InternalKvState in org.apache.flink.runtime.query
Methods in org.apache.flink.runtime.query that return InternalKvState Modifier and Type Method Description InternalKvState<K,N,V>
KvStateEntry. getState()
Methods in org.apache.flink.runtime.query with parameters of type InternalKvState Modifier and Type Method Description org.apache.flink.queryablestate.KvStateID
KvStateRegistry. registerKvState(org.apache.flink.api.common.JobID jobId, JobVertexID jobVertexId, KeyGroupRange keyGroupRange, String registrationName, InternalKvState<?,?,?> kvState, ClassLoader userClassLoader)
Registers the KvState instance and returns the assigned ID.void
TaskKvStateRegistry. registerKvState(KeyGroupRange keyGroupRange, String registrationName, InternalKvState<?,?,?> kvState, ClassLoader userClassLoader)
Registers the KvState instance at the KvStateRegistry.Constructors in org.apache.flink.runtime.query with parameters of type InternalKvState Constructor Description KvStateEntry(InternalKvState<K,N,V> state, ClassLoader userClassLoader)
-
Uses of InternalKvState in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type InternalKvState Modifier and Type Method Description void
AbstractKeyedStateBackend. publishQueryableStateIfEnabled(org.apache.flink.api.common.state.StateDescriptor<?,?> stateDescriptor, InternalKvState<?,?,?> kvState)
-
Uses of InternalKvState in org.apache.flink.runtime.state.heap
Classes in org.apache.flink.runtime.state.heap that implement InternalKvState Modifier and Type Class Description class
AbstractHeapState<K,N,SV>
Base class for partitionedState
implementations that are backed by a regular heap hash map. -
Uses of InternalKvState in org.apache.flink.runtime.state.internal
Subinterfaces of InternalKvState in org.apache.flink.runtime.state.internal Modifier and Type Interface Description interface
InternalAggregatingState<K,N,IN,SV,OUT>
The peer to theAggregatingState
in the internal state type hierarchy.interface
InternalAppendingState<K,N,IN,SV,OUT>
The peer to theAppendingState
in the internal state type hierarchy.interface
InternalListState<K,N,T>
The peer to theListState
in the internal state type hierarchy.interface
InternalMapState<K,N,UK,UV>
The peer to theMapState
in the internal state type hierarchy.interface
InternalMergingState<K,N,IN,SV,OUT>
The peer to theMergingState
in the internal state type hierarchy.interface
InternalReducingState<K,N,T>
The peer to theReducingState
in the internal state type hierarchy.interface
InternalValueState<K,N,T>
The peer to theValueState
in the internal state type hierarchy. -
Uses of InternalKvState in org.apache.flink.runtime.state.metrics
Classes in org.apache.flink.runtime.state.metrics with type parameters of type InternalKvState Modifier and Type Class Description class
LatencyTrackingStateFactory<K,N,V,S extends org.apache.flink.api.common.state.State,IS extends InternalKvState<K,N,?>>
Factory to createAbstractLatencyTrackState
.Methods in org.apache.flink.runtime.state.metrics that return InternalKvState Modifier and Type Method Description static <K,N,V,S extends org.apache.flink.api.common.state.State>
InternalKvState<K,N,?>LatencyTrackingStateFactory. createStateAndWrapWithLatencyTrackingIfEnabled(InternalKvState<K,N,?> kvState, org.apache.flink.api.common.state.StateDescriptor<S,V> stateDescriptor, LatencyTrackingStateConfig latencyTrackingStateConfig)
Create latency tracking state if enabled.Methods in org.apache.flink.runtime.state.metrics with parameters of type InternalKvState Modifier and Type Method Description static <K,N,V,S extends org.apache.flink.api.common.state.State>
InternalKvState<K,N,?>LatencyTrackingStateFactory. createStateAndWrapWithLatencyTrackingIfEnabled(InternalKvState<K,N,?> kvState, org.apache.flink.api.common.state.StateDescriptor<S,V> stateDescriptor, LatencyTrackingStateConfig latencyTrackingStateConfig)
Create latency tracking state if enabled. -
Uses of InternalKvState in org.apache.flink.runtime.state.v2.adaptor
Classes in org.apache.flink.runtime.state.v2.adaptor with type parameters of type InternalKvState Modifier and Type Class Description class
StateAdaptor<K,N,S extends InternalKvState<K,N,?>>
An base implementation of state adaptor from v1 to v2.
-