Class AsyncRequest<K>
- java.lang.Object
-
- org.apache.flink.runtime.asyncprocessing.AsyncRequest<K>
-
- Direct Known Subclasses:
SimpleAsyncExecutionController.RunnableTask
,StateRequest
,SyncPointRequest
public abstract class AsyncRequest<K> extends Object
-
-
Field Summary
Fields Modifier and Type Field Description protected org.apache.flink.core.asyncprocessing.InternalAsyncFuture
asyncFuture
The future to collect the result of the request.protected RecordContext<K>
context
The record context of this request.protected boolean
sync
-
Constructor Summary
Constructors Constructor Description AsyncRequest(RecordContext<K> context, boolean sync, org.apache.flink.core.asyncprocessing.InternalAsyncFuture asyncFuture)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description org.apache.flink.core.asyncprocessing.InternalAsyncFuture
getFuture()
RecordContext<K>
getRecordContext()
boolean
isSync()
-
-
-
Field Detail
-
context
protected final RecordContext<K> context
The record context of this request.
-
sync
protected final boolean sync
-
asyncFuture
protected final org.apache.flink.core.asyncprocessing.InternalAsyncFuture asyncFuture
The future to collect the result of the request.
-
-
Constructor Detail
-
AsyncRequest
public AsyncRequest(RecordContext<K> context, boolean sync, org.apache.flink.core.asyncprocessing.InternalAsyncFuture asyncFuture)
-
-
Method Detail
-
getRecordContext
public RecordContext<K> getRecordContext()
-
isSync
public boolean isSync()
-
getFuture
public org.apache.flink.core.asyncprocessing.InternalAsyncFuture getFuture()
-
-