@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.CanEmitBatchOfRecordsChecker
checkpointStorage, configuration, inputProcessor, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
StreamIterationHead(Environment env) |
Modifier and Type | Method and Description |
---|---|
protected void |
cleanUpInternal() |
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.
|
getCheckpointBarrierHandler
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, cancel, cancelTask, cleanUp, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCanEmitBatchOfRecords, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
public StreamIterationHead(Environment env) throws Exception
Exception
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 cleanUpInternal()
cleanUpInternal
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–2024 The Apache Software Foundation. All rights reserved.