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 class
AsyncExecutionController<K>
The Async Execution Controller (AEC) receives processing requests from operators, and put them into execution according to some strategies.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 void
AsyncKeyedStateBackend. 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 StateRequestHandler
AbstractKeyedState. stateRequestHandler
Methods in org.apache.flink.runtime.state.v2 that return StateRequestHandler Modifier and Type Method Description StateRequestHandler
AbstractKeyedState. getStateRequestHandler()
Constructors in org.apache.flink.runtime.state.v2 with parameters of type StateRequestHandler Constructor Description AbstractAggregatingState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.AggregatingStateDescriptor<IN,ACC,OUT> stateDescriptor)
Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.AbstractKeyedState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.StateDescriptor<V> stateDescriptor)
Creates a new AbstractKeyedState with the given asyncExecutionController and stateDescriptor.AbstractListState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.ListStateDescriptor<V> stateDescriptor)
AbstractMapState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.MapStateDescriptor<UK,V> stateDescriptor)
AbstractReducingState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.ReducingStateDescriptor<V> stateDescriptor)
AbstractValueState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.state.v2.ValueStateDescriptor<V> valueStateDescriptor)
-
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 void
AsyncKeyedStateBackendAdaptor. setup(StateRequestHandler stateRequestHandler)
-