@Internal public class StreamIterationHead<OUT> extends OneInputStreamTask<OUT,OUT>
StreamTask
that is used for executing feedback edges. This is used in
combination with StreamIterationTail
.checkpointStorage, configuration, inputProcessor, mailboxProcessor, mainOperator, operatorChain, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
构造器和说明 |
---|
StreamIterationHead(org.apache.flink.runtime.execution.Environment env) |
限定符和类型 | 方法和说明 |
---|---|
protected void |
cleanUpInternal() |
static String |
createBrokerIdString(org.apache.flink.api.common.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. processing one event from the
input).
|
getCheckpointBarrierHandler
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, assertTriggeringCheckpointExceptions, cancel, cancelTask, cleanUp, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
protected void processInput(MailboxDefaultAction.Controller controller) throws Exception
StreamTask
processInput
在类中 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
在类中 OneInputStreamTask<OUT,OUT>
protected void cleanUpInternal()
cleanUpInternal
在类中 StreamTask<OUT,OneInputStreamOperator<OUT,OUT>>
public static String createBrokerIdString(org.apache.flink.api.common.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–2022 The Apache Software Foundation. All rights reserved.