Uses of Interface
org.apache.flink.runtime.state.KeyedStateFunction
-
Packages that use KeyedStateFunction 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.streaming.api.functions.co org.apache.flink.streaming.api.operators.sorted.state -
-
Uses of KeyedStateFunction in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type KeyedStateFunction Modifier and Type Method Description <N,S extends org.apache.flink.api.common.state.State,T>
voidAbstractKeyedStateBackend. applyToAllKeys(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor, KeyedStateFunction<K,S> function)
<N,S extends org.apache.flink.api.common.state.State,T>
voidAbstractKeyedStateBackend. applyToAllKeys(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor, KeyedStateFunction<K,S> function, AbstractKeyedStateBackend.PartitionStateFactory partitionStateFactory)
<N,S extends org.apache.flink.api.common.state.State,T>
voidKeyedStateBackend. applyToAllKeys(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor, KeyedStateFunction<K,S> function)
Applies the providedKeyedStateFunction
to the state with the providedStateDescriptor
of all the currently active keys. -
Uses of KeyedStateFunction in org.apache.flink.runtime.state.heap
Methods in org.apache.flink.runtime.state.heap with parameters of type KeyedStateFunction Modifier and Type Method Description <N,S extends org.apache.flink.api.common.state.State,T>
voidHeapKeyedStateBackend. applyToAllKeys(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor, KeyedStateFunction<K,S> function, AbstractKeyedStateBackend.PartitionStateFactory partitionStateFactory)
-
Uses of KeyedStateFunction in org.apache.flink.streaming.api.functions.co
Methods in org.apache.flink.streaming.api.functions.co with parameters of type KeyedStateFunction Modifier and Type Method Description abstract <VS,S extends org.apache.flink.api.common.state.State>
voidKeyedBroadcastProcessFunction.Context. applyToKeyedState(org.apache.flink.api.common.state.StateDescriptor<S,VS> stateDescriptor, KeyedStateFunction<KS,S> function)
Applies the providedfunction
to the state associated with the providedstate descriptor
. -
Uses of KeyedStateFunction in org.apache.flink.streaming.api.operators.sorted.state
Methods in org.apache.flink.streaming.api.operators.sorted.state with parameters of type KeyedStateFunction Modifier and Type Method Description <N,S extends org.apache.flink.api.common.state.State,T>
voidBatchExecutionKeyedStateBackend. applyToAllKeys(N namespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.StateDescriptor<S,T> stateDescriptor, KeyedStateFunction<K,S> function)
-