@Internal public class StreamIterationTail<IN> extends OneInputStreamTask<IN,IN>
StreamTask
that is used for executing feedback edges. This is used in
combination with StreamIterationHead
.StreamTask.AsyncCheckpointRunnable
configuration, headOperator, 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() |
cancelTask, cleanup, run
abortCheckpointOnBarrier, cancel, createCheckpointExceptionHandlerFactory, createStreamRecordWriters, createStreamTaskStateInitializer, finalize, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, toString, triggerCheckpoint, triggerCheckpointOnBarrier
Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.