Uses of Interface
org.apache.flink.runtime.asyncprocessing.StateRequestHandler
-
Packages that use StateRequestHandler Package Description org.apache.flink.runtime.asyncprocessing org.apache.flink.runtime.state org.apache.flink.runtime.state.v2 org.apache.flink.runtime.state.v2.adaptor -
-
Uses of StateRequestHandler in org.apache.flink.runtime.asyncprocessing
Classes in org.apache.flink.runtime.asyncprocessing that implement StateRequestHandler Modifier and Type Class Description classStateExecutionController<K>TheStateExecutionControlleris responsible for handlingStateRequests.Constructors in org.apache.flink.runtime.asyncprocessing with parameters of type StateRequestHandler Constructor Description AbstractStateIterator(org.apache.flink.api.common.state.v2.State originalState, StateRequestType requestType, StateRequestHandler stateHandler, Collection<T> partialResult) -
Uses of StateRequestHandler in org.apache.flink.runtime.state
Methods in org.apache.flink.runtime.state with parameters of type StateRequestHandler Modifier and Type Method Description voidAsyncKeyedStateBackend. setup(StateRequestHandler stateRequestHandler)Initializes with some contexts. -
Uses of StateRequestHandler in org.apache.flink.runtime.state.v2
Fields in org.apache.flink.runtime.state.v2 declared as StateRequestHandler Modifier and Type Field Description protected StateRequestHandlerAbstractKeyedState. stateRequestHandlerMethods in org.apache.flink.runtime.state.v2 that return StateRequestHandler Modifier and Type Method Description StateRequestHandlerAbstractKeyedState. getStateRequestHandler()Constructors in org.apache.flink.runtime.state.v2 with parameters of type StateRequestHandler Constructor Description AbstractAggregatingState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.functions.AggregateFunction<IN,ACC,OUT> aggregateFunction, org.apache.flink.api.common.typeutils.TypeSerializer<ACC> valueSerializer)Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.AbstractKeyedState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> valueSerializer)Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.AbstractListState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> serializer)AbstractMapState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> serializer)AbstractReducingState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.functions.ReduceFunction<V> reduceFunction, org.apache.flink.api.common.typeutils.TypeSerializer<V> valueSerializer)AbstractValueState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> valueSerializer) -
Uses of StateRequestHandler in org.apache.flink.runtime.state.v2.adaptor
Methods in org.apache.flink.runtime.state.v2.adaptor with parameters of type StateRequestHandler Modifier and Type Method Description voidAsyncKeyedStateBackendAdaptor. setup(StateRequestHandler stateRequestHandler)
-