Uses of Interface
org.apache.flink.api.common.state.v2.StateIterator
-
-
Uses of StateIterator in org.apache.flink.api.common.state.v2
Methods in org.apache.flink.api.common.state.v2 that return types with arguments of type StateIterator Modifier and Type Method Description StateFuture<StateIterator<Map.Entry<UK,UV>>>
MapState. asyncEntries()
Returns the current iterator for all the mappings of this state asynchronously.StateFuture<StateIterator<UK>>
MapState. asyncKeys()
Returns the current iterator for all the keys of this state asynchronously.StateFuture<StateIterator<UV>>
MapState. asyncValues()
Returns the current iterator for all the values of this state asynchronously. -
Uses of StateIterator in org.apache.flink.runtime.asyncprocessing
Classes in org.apache.flink.runtime.asyncprocessing that implement StateIterator Modifier and Type Class Description class
AbstractStateIterator<T>
AStateIterator
implementation to facilitate async data load of iterator. -
Uses of StateIterator in org.apache.flink.runtime.state.v2
Methods in org.apache.flink.runtime.state.v2 that return types with arguments of type StateIterator Modifier and Type Method Description StateFuture<StateIterator<Map.Entry<UK,V>>>
AbstractMapState. asyncEntries()
StateFuture<StateIterator<V>>
AbstractListState. asyncGet()
StateFuture<StateIterator<UK>>
AbstractMapState. asyncKeys()
StateFuture<StateIterator<V>>
AbstractMapState. asyncValues()
Constructors in org.apache.flink.runtime.state.v2 with parameters of type StateIterator Constructor Description SyncIteratorWrapper(StateIterator<T> stateIterator)
-
Uses of StateIterator in org.apache.flink.runtime.state.v2.adaptor
Classes in org.apache.flink.runtime.state.v2.adaptor that implement StateIterator Modifier and Type Class Description class
CompleteStateIterator<T>
AStateIterator
that has all elements.Methods in org.apache.flink.runtime.state.v2.adaptor that return types with arguments of type StateIterator Modifier and Type Method Description StateFuture<StateIterator<Map.Entry<UK,UV>>>
MapStateAdaptor. asyncEntries()
StateFuture<StateIterator<V>>
ListStateAdaptor. asyncGet()
StateFuture<StateIterator<UK>>
MapStateAdaptor. asyncKeys()
StateFuture<StateIterator<UV>>
MapStateAdaptor. asyncValues()
-
Uses of StateIterator in org.apache.flink.state.forst
Classes in org.apache.flink.state.forst that implement StateIterator Modifier and Type Class Description class
ForStListIterator<V>
The forst implementation for list iterator.class
ForStMapIterator<T>
The map iterator implementation for ForStDB.Methods in org.apache.flink.state.forst that return types with arguments of type StateIterator Modifier and Type Method Description ForStDBGetRequest<K,N,List<V>,StateIterator<V>>
ForStListState. buildDBGetRequest(StateRequest<?,?,?,?> stateRequest)
Constructor parameters in org.apache.flink.state.forst with type arguments of type StateIterator Constructor Description ForStDBMapEntryIterRequest(ContextKey<K,N> contextKey, ForStMapState<K,N,UK,UV> table, StateRequestHandler stateRequestHandler, org.forstdb.RocksIterator rocksIterator, InternalStateFuture<StateIterator<Map.Entry<UK,UV>>> future)
ForStDBMapKeyIterRequest(ContextKey<K,N> contextKey, ForStMapState<K,N,UK,UV> table, StateRequestHandler stateRequestHandler, org.forstdb.RocksIterator rocksIterator, InternalStateFuture<StateIterator<UK>> future)
ForStDBMapValueIterRequest(ContextKey<K,N> contextKey, ForStMapState<K,N,UK,UV> table, StateRequestHandler stateRequestHandler, org.forstdb.RocksIterator rocksIterator, InternalStateFuture<StateIterator<UV>> future)
-