@Internal public class StreamIterationTail<IN> extends OneInputStreamTask<IN,IN>
StreamTask
that is used for executing feedback edges. This is used in
combination with StreamIterationHead
.configuration, headOperator, inputProcessor, mailboxProcessor, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
StreamIterationTail(org.apache.flink.runtime.execution.Environment environment) |
Modifier and Type | Method and Description |
---|---|
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, beforeInvoke, cancel, cancelTask, cleanup, cleanUpInvoke, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, executeInTaskThread, finalize, finishTask, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, runMailboxStep, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.