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.KvStateIDKvStateRegistry. 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.voidTaskKvStateRegistry. 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 voidAbstractKeyedStateBackend. 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 classAbstractHeapState<K,N,SV>Base class for partitionedStateimplementations 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 interfaceInternalAggregatingState<K,N,IN,SV,OUT>The peer to theAggregatingStatein the internal state type hierarchy.interfaceInternalAppendingState<K,N,IN,SV,OUT>The peer to theAppendingStatein the internal state type hierarchy.interfaceInternalListState<K,N,T>The peer to theListStatein the internal state type hierarchy.interfaceInternalMapState<K,N,UK,UV>The peer to theMapStatein the internal state type hierarchy.interfaceInternalMergingState<K,N,IN,SV,OUT>The peer to theMergingStatein the internal state type hierarchy.interfaceInternalReducingState<K,N,T>The peer to theReducingStatein the internal state type hierarchy.interfaceInternalValueState<K,N,T>The peer to theValueStatein 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 classMetricsTrackingStateFactory<K,N,V,S extends org.apache.flink.api.common.state.State,IS extends InternalKvState<K,N,?>>Factory to createAbstractMetricsTrackState.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,?>MetricsTrackingStateFactory. createStateAndWrapWithMetricsTrackingIfEnabled(InternalKvState<K,N,?> kvState, KeyedStateBackend<K> keyedStateBackend, org.apache.flink.api.common.state.StateDescriptor<S,V> stateDescriptor, LatencyTrackingStateConfig latencyTrackingStateConfig, SizeTrackingStateConfig sizeTrackingStateConfig)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,?>MetricsTrackingStateFactory. createStateAndWrapWithMetricsTrackingIfEnabled(InternalKvState<K,N,?> kvState, KeyedStateBackend<K> keyedStateBackend, org.apache.flink.api.common.state.StateDescriptor<S,V> stateDescriptor, LatencyTrackingStateConfig latencyTrackingStateConfig, SizeTrackingStateConfig sizeTrackingStateConfig)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 classStateAdaptor<K,N,S extends InternalKvState<K,N,?>>An base implementation of state adaptor from v1 to v2.
-