@Internal public class StreamIterationHead<OUT> extends OneInputStreamTask<OUT,OUT>
StreamTask
that is used for executing feedback edges. This is used in
combination with StreamIterationTail
.StreamTask.AsyncCheckpointRunnable
configuration, headOperator, inputProcessor, mailboxProcessor, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
StreamIterationHead(Environment env) |
Modifier and Type | Method and Description |
---|---|
protected void |
cleanup() |
static String |
createBrokerIdString(JobID jid,
String iterationID,
int subtaskIndex)
Creates the identification string with which head and tail task find the shared blocking
queue for the back channel.
|
void |
init() |
protected void |
processInput(MailboxDefaultAction.Controller controller)
This method implements the default action of the task (e.g.
|
abortCheckpointOnBarrier, advanceToEndOfEventTime, cancel, cancelTask, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, finalize, finishTask, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getCompletionFuture, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, handleCheckpointException, invoke, isCanceled, isFailing, isRunning, notifyCheckpointCompleteAsync, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
getCurrentNumberOfSubtasks, getEnvironment, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, setShouldInterruptOnCancel, shouldInterruptOnCancel
public StreamIterationHead(Environment env)
protected void processInput(MailboxDefaultAction.Controller controller) throws Exception
StreamTask
processInput
in class StreamTask<OUT,OneInputStreamOperator<OUT,OUT>>
controller
- controller object for collaborative interaction between the action and the stream task.Exception
- on any problems in the action.public void init()
init
in class OneInputStreamTask<OUT,OUT>
protected void cleanup()
cleanup
in class StreamTask<OUT,OneInputStreamOperator<OUT,OUT>>
public static String createBrokerIdString(JobID jid, String iterationID, int subtaskIndex)
jid
- The job ID.iterationID
- The id of the iteration in the job.subtaskIndex
- The parallel subtask numberCopyright © 2014–2020 The Apache Software Foundation. All rights reserved.