Class AbstractValueState<K,N,V>
- java.lang.Object
-
- org.apache.flink.runtime.state.v2.AbstractKeyedState<K,N,V>
-
- org.apache.flink.runtime.state.v2.AbstractValueState<K,N,V>
-
- Type Parameters:
K- The type of key the state is associated to.V- The type of values kept internally in state.
- All Implemented Interfaces:
org.apache.flink.api.common.state.v2.State,org.apache.flink.api.common.state.v2.ValueState<V>,InternalKeyedState<K,N,V>,InternalPartitionedState<N>,InternalValueState<K,N,V>
public class AbstractValueState<K,N,V> extends AbstractKeyedState<K,N,V> implements InternalValueState<K,N,V>
A default implementation ofValueStatewhich delegates all async requests toAsyncExecutionController.
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.state.v2.AbstractKeyedState
stateRequestHandler
-
-
Constructor Summary
Constructors Constructor Description AbstractValueState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> valueSerializer)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.api.common.state.v2.StateFuture<Void>asyncUpdate(V value)org.apache.flink.api.common.state.v2.StateFuture<V>asyncValue()voidupdate(V value)Vvalue()-
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
-
AbstractValueState
public AbstractValueState(StateRequestHandler stateRequestHandler, org.apache.flink.api.common.typeutils.TypeSerializer<V> valueSerializer)
-
-
Method Detail
-
asyncValue
public final org.apache.flink.api.common.state.v2.StateFuture<V> asyncValue()
- Specified by:
asyncValuein interfaceorg.apache.flink.api.common.state.v2.ValueState<K>
-
asyncUpdate
public final org.apache.flink.api.common.state.v2.StateFuture<Void> asyncUpdate(V value)
- Specified by:
asyncUpdatein interfaceorg.apache.flink.api.common.state.v2.ValueState<K>
-
value
public V value()
- Specified by:
valuein interfaceorg.apache.flink.api.common.state.v2.ValueState<K>
-
-