Class AbstractMapState<K,N,UK,V>
- java.lang.Object
-
- org.apache.flink.runtime.state.v2.AbstractKeyedState<K,N,V>
-
- org.apache.flink.runtime.state.v2.AbstractMapState<K,N,UK,V>
-
- Type Parameters:
K- The type of partitioned key the state is associated to.UK- The type of user key of this state.V- The type of values kept internally in state.
- All Implemented Interfaces:
org.apache.flink.api.common.state.v2.MapState<UK,V>,org.apache.flink.api.common.state.v2.State,InternalKeyedState<K,N,V>,InternalMapState<K,N,UK,V>,InternalPartitionedState<N>
public class AbstractMapState<K,N,UK,V> extends AbstractKeyedState<K,N,V> implements InternalMapState<K,N,UK,V>
A default implementation ofMapStatewhich delegates all async requests toStateRequestHandler.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.state.v2.AbstractKeyedState
stateRequestHandler
-
-
Constructor Summary
Constructors Constructor Description AbstractMapState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> serializer)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.api.common.state.v2.StateFuture<Boolean>asyncContains(UK key)org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<Map.Entry<UK,V>>>asyncEntries()org.apache.flink.api.common.state.v2.StateFuture<V>asyncGet(UK key)org.apache.flink.api.common.state.v2.StateFuture<Boolean>asyncIsEmpty()org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<UK>>asyncKeys()org.apache.flink.api.common.state.v2.StateFuture<Void>asyncPut(UK key, V value)org.apache.flink.api.common.state.v2.StateFuture<Void>asyncPutAll(Map<UK,V> map)org.apache.flink.api.common.state.v2.StateFuture<Void>asyncRemove(UK key)org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<V>>asyncValues()booleancontains(UK key)Iterable<Map.Entry<UK,V>>entries()Vget(UK key)booleanisEmpty()Iterator<Map.Entry<UK,V>>iterator()Iterable<UK>keys()voidput(UK key, V value)voidputAll(Map<UK,V> map)voidremove(UK key)Iterable<V>values()-
Methods inherited from class org.apache.flink.runtime.state.v2.AbstractKeyedState
asyncClear, clear, getStateRequestHandler, getValueSerializer, handleRequest, handleRequestSync, setCurrentNamespace
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.runtime.state.v2.internal.InternalPartitionedState
setCurrentNamespace
-
-
-
-
Constructor Detail
-
AbstractMapState
public AbstractMapState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> serializer)
-
-
Method Detail
-
asyncPutAll
public org.apache.flink.api.common.state.v2.StateFuture<Void> asyncPutAll(Map<UK,V> map)
-
asyncContains
public org.apache.flink.api.common.state.v2.StateFuture<Boolean> asyncContains(UK key)
-
asyncEntries
public org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<Map.Entry<UK,V>>> asyncEntries()
-
asyncKeys
public org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<UK>> asyncKeys()
-
asyncValues
public org.apache.flink.api.common.state.v2.StateFuture<org.apache.flink.api.common.state.v2.StateIterator<V>> asyncValues()
-
asyncIsEmpty
public org.apache.flink.api.common.state.v2.StateFuture<Boolean> asyncIsEmpty()
-
remove
public void remove(UK key)
-
contains
public boolean contains(UK key)
-
-