Uses of Class
org.apache.flink.runtime.asyncprocessing.declare.DeclaredVariable
-
-
Uses of DeclaredVariable in org.apache.flink.runtime.asyncprocessing.declare
Methods in org.apache.flink.runtime.asyncprocessing.declare that return DeclaredVariable Modifier and Type Method Description <T> DeclaredVariable<T>
DeclarationContext. declareVariable(org.apache.flink.api.common.typeutils.TypeSerializer<T> serializer, String name, Supplier<T> initialValue)
Declare a variable that will keep value across callback with same context. -
Uses of DeclaredVariable in org.apache.flink.runtime.asyncprocessing.declare.state
Methods in org.apache.flink.runtime.asyncprocessing.declare.state with parameters of type DeclaredVariable Modifier and Type Method Description static <N,S extends org.apache.flink.api.common.state.v2.State>
SStateWithDeclaredNamespace. create(S state, DeclaredVariable<N> declaredNamespace)
Constructors in org.apache.flink.runtime.asyncprocessing.declare.state with parameters of type DeclaredVariable Constructor Description StateWithDeclaredNamespace(InternalKeyedState<K,N,V> state, DeclaredVariable<N> declaredNamespace)
-
Uses of DeclaredVariable in org.apache.flink.runtime.asyncprocessing.operators
Constructors in org.apache.flink.runtime.asyncprocessing.operators with parameters of type DeclaredVariable Constructor Description TimestampedCollectorWithDeclaredVariable(Output<StreamRecord<T>> output, DeclaredVariable<Long> timestamp)
Creates a newTimestampedCollectorWithDeclaredVariable
that wraps the givenOutput
and givenDeclaredVariable
that holds the timestamp. -
Uses of DeclaredVariable in org.apache.flink.runtime.asyncprocessing.operators.windowing
Fields in org.apache.flink.runtime.asyncprocessing.operators.windowing declared as DeclaredVariable Modifier and Type Field Description protected DeclaredVariable<W>
AsyncWindowOperator.AbstractPerWindowStateStore. window
protected DeclaredVariable<W>
AsyncWindowOperator.Context. window
protected DeclaredVariable<W>
AsyncWindowOperator.WindowContext. window
protected DeclaredVariable<W>
AsyncWindowOperator. windowDeclaredVariable
Constructors in org.apache.flink.runtime.asyncprocessing.operators.windowing with parameters of type DeclaredVariable Constructor Description AbstractPerWindowStateStore(AsyncKeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig, DeclaredVariable<W> window)
Context(DeclaredVariable<W> window)
PerWindowStateStore(AsyncKeyedStateBackend<?> keyedStateBackend, org.apache.flink.api.common.ExecutionConfig executionConfig, DeclaredVariable<W> window)
WindowContext(DeclaredVariable<W> window)
-