Class StateRequest<K,N,IN,OUT>
- java.lang.Object
-
- org.apache.flink.runtime.asyncprocessing.AsyncRequest<K>
-
- org.apache.flink.runtime.asyncprocessing.StateRequest<K,N,IN,OUT>
-
- Type Parameters:
K
- Type of partitioned key.IN
- Type of input of this request.N
- Type of namespace.OUT
- Type of value that request will return.
- All Implemented Interfaces:
Serializable
public class StateRequest<K,N,IN,OUT> extends AsyncRequest<K> implements Serializable
A request encapsulates the necessary data to perform a state request.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.runtime.asyncprocessing.AsyncRequest
asyncFuture, context, sync
-
-
Constructor Summary
Constructors Constructor Description StateRequest(org.apache.flink.api.common.state.v2.State state, StateRequestType type, boolean sync, IN payload, org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT> stateFuture, RecordContext<K> context)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT>
getFuture()
N
getNamespace()
IN
getPayload()
StateRequestType
getRequestType()
org.apache.flink.api.common.state.v2.State
getState()
-
Methods inherited from class org.apache.flink.runtime.asyncprocessing.AsyncRequest
getRecordContext, isSync
-
-
-
-
Constructor Detail
-
StateRequest
public StateRequest(@Nonnull org.apache.flink.api.common.state.v2.State state, StateRequestType type, boolean sync, @Nullable IN payload, org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT> stateFuture, RecordContext<K> context)
-
-
Method Detail
-
getRequestType
public StateRequestType getRequestType()
-
getPayload
@Nullable public IN getPayload()
-
getState
@Nullable public org.apache.flink.api.common.state.v2.State getState()
-
getFuture
public org.apache.flink.core.asyncprocessing.InternalAsyncFuture<OUT> getFuture()
- Overrides:
getFuture
in classAsyncRequest<K>
-
getNamespace
@Nonnull public N getNamespace()
-
-