public static interface StageRunner.StageMessageDispatcher<E> extends AutoCloseable
Sorter
via sendResult(MutableObjectIterator)
Modifier and Type | Method and Description |
---|---|
org.apache.flink.runtime.operators.sort.CircularElement<E> |
poll(StageRunner.SortStage stage)
Retrieves and removes the head of the given stage queue, or returns
null if the
queue is empty. |
void |
send(StageRunner.SortStage stage,
org.apache.flink.runtime.operators.sort.CircularElement<E> element)
Sends a message to the given stage.
|
void |
sendResult(MutableObjectIterator<E> result)
Sends a result to the corresponding
Sorter . |
org.apache.flink.runtime.operators.sort.CircularElement<E> |
take(StageRunner.SortStage stage)
Retrieves and removes the head of the given queue, waiting if necessary until an element
becomes available.
|
close
void send(StageRunner.SortStage stage, org.apache.flink.runtime.operators.sort.CircularElement<E> element)
org.apache.flink.runtime.operators.sort.CircularElement<E> take(StageRunner.SortStage stage) throws InterruptedException
InterruptedException
org.apache.flink.runtime.operators.sort.CircularElement<E> poll(StageRunner.SortStage stage)
null
if the
queue is empty.null
if the queue is emptyvoid sendResult(MutableObjectIterator<E> result)
Sorter
.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.