public interface RemoteTask
Modifier and Type | Method and Description |
---|---|
void |
abort() |
void |
addFinalTaskInfoListener(StateMachine.StateChangeListener<TaskInfo> stateChangeListener)
Add a listener for the final task info.
|
void |
addSplits(com.google.common.collect.Multimap<PlanNodeId,Split> splits) |
void |
addStateChangeListener(StateMachine.StateChangeListener<TaskStatus> stateChangeListener)
Listener is always notified asynchronously using a dedicated notification thread pool so, care should
be taken to avoid leaking
this when adding a listener in a constructor. |
void |
cancel() |
String |
getNodeId() |
PartitionedSplitsInfo |
getPartitionedSplitsInfo() |
PartitionedSplitsInfo |
getQueuedPartitionedSplitsInfo() |
URI |
getRemoteTaskLocation()
TODO: this should be merged into getTaskStatus once full thrift support is in-place for v1/task
|
TaskId |
getTaskId() |
TaskInfo |
getTaskInfo() |
TaskStatus |
getTaskStatus() |
int |
getUnacknowledgedPartitionedSplitCount() |
void |
noMoreSplits(PlanNodeId sourceId) |
void |
noMoreSplits(PlanNodeId sourceId,
Lifespan lifespan) |
com.google.common.util.concurrent.ListenableFuture<?> |
removeRemoteSource(TaskId remoteSourceTaskId) |
void |
setOutputBuffers(OutputBuffers outputBuffers) |
void |
start() |
com.google.common.util.concurrent.ListenableFuture<?> |
whenSplitQueueHasSpace(long weightThreshold) |
TaskId getTaskId()
String getNodeId()
TaskInfo getTaskInfo()
TaskStatus getTaskStatus()
URI getRemoteTaskLocation()
void start()
void addSplits(com.google.common.collect.Multimap<PlanNodeId,Split> splits)
void noMoreSplits(PlanNodeId sourceId)
void noMoreSplits(PlanNodeId sourceId, Lifespan lifespan)
void setOutputBuffers(OutputBuffers outputBuffers)
com.google.common.util.concurrent.ListenableFuture<?> removeRemoteSource(TaskId remoteSourceTaskId)
void addStateChangeListener(StateMachine.StateChangeListener<TaskStatus> stateChangeListener)
this
when adding a listener in a constructor. Additionally, it is
possible notifications are observed out of order due to the asynchronous execution.void addFinalTaskInfoListener(StateMachine.StateChangeListener<TaskInfo> stateChangeListener)
this
when adding a listener in a constructor. Additionally, it is
possible notifications are observed out of order due to the asynchronous execution.com.google.common.util.concurrent.ListenableFuture<?> whenSplitQueueHasSpace(long weightThreshold)
void cancel()
void abort()
PartitionedSplitsInfo getPartitionedSplitsInfo()
PartitionedSplitsInfo getQueuedPartitionedSplitsInfo()
int getUnacknowledgedPartitionedSplitCount()
Copyright © 2012–2022. All rights reserved.