Uses of Interface
org.apache.flink.runtime.state.AsyncKeyedStateBackend
-
-
Uses of AsyncKeyedStateBackend in org.apache.flink.runtime.asyncprocessing.operators
Methods in org.apache.flink.runtime.asyncprocessing.operators that return AsyncKeyedStateBackend Modifier and Type Method Description <K> AsyncKeyedStateBackend<K>
AbstractAsyncStateStreamOperator. getAsyncKeyedStateBackend()
-
Uses of AsyncKeyedStateBackend in org.apache.flink.runtime.asyncprocessing.operators.windowing
Constructors in org.apache.flink.runtime.asyncprocessing.operators.windowing with parameters of type AsyncKeyedStateBackend Constructor Description AbstractPerWindowStateStore(AsyncKeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig, DeclaredVariable<W> window)
PerWindowStateStore(AsyncKeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig, DeclaredVariable<W> window)
-
Uses of AsyncKeyedStateBackend in org.apache.flink.runtime.state
Fields in org.apache.flink.runtime.state declared as AsyncKeyedStateBackend Modifier and Type Field Description protected AsyncKeyedStateBackend<?>
DefaultKeyedStateStore. asyncKeyedStateBackend
Methods in org.apache.flink.runtime.state that return AsyncKeyedStateBackend Modifier and Type Method Description default <K> AsyncKeyedStateBackend<K>
StateBackend. createAsyncKeyedStateBackend(StateBackend.KeyedStateBackendParameters<K> parameters)
Creates a newAsyncKeyedStateBackend
which supports to access keyed state asynchronously.Constructors in org.apache.flink.runtime.state with parameters of type AsyncKeyedStateBackend Constructor Description DefaultKeyedStateStore(AsyncKeyedStateBackend<?> asyncKeyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
DefaultKeyedStateStore(KeyedStateBackend<?> keyedStateBackend, AsyncKeyedStateBackend<?> asyncKeyedStateBackend, org.apache.flink.api.common.functions.SerializerFactory serializerFactory)
-
Uses of AsyncKeyedStateBackend in org.apache.flink.runtime.state.v2.adaptor
Classes in org.apache.flink.runtime.state.v2.adaptor that implement AsyncKeyedStateBackend Modifier and Type Class Description class
AsyncKeyedStateBackendAdaptor<K>
A adaptor that transformsKeyedStateBackend
intoAsyncKeyedStateBackend
. -
Uses of AsyncKeyedStateBackend in org.apache.flink.runtime.state.v2.ttl
Methods in org.apache.flink.runtime.state.v2.ttl with parameters of type AsyncKeyedStateBackend Modifier and Type Method Description static <K,N,SV,TTLSV,S extends org.apache.flink.api.common.state.v2.State,IS extends S>
ISTtlStateFactory. createStateAndWrapWithTtlIfEnabled(N defaultNamespace, org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer, org.apache.flink.api.common.state.v2.StateDescriptor<SV> stateDesc, AsyncKeyedStateBackend<K> stateBackend, TtlTimeProvider timeProvider)
-
Uses of AsyncKeyedStateBackend in org.apache.flink.streaming.api.operators
Methods in org.apache.flink.streaming.api.operators that return AsyncKeyedStateBackend Modifier and Type Method Description AsyncKeyedStateBackend<?>
StreamOperatorStateContext. asyncKeyedStateBackend()
Returns the async keyed state backend for the stream operator.<K> AsyncKeyedStateBackend<K>
StreamOperatorStateHandler. getAsyncKeyedStateBackend()
-