Class OneInputStreamTask<IN,OUT>
- java.lang.Object
-
- org.apache.flink.streaming.runtime.tasks.StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
-
- org.apache.flink.streaming.runtime.tasks.OneInputStreamTask<IN,OUT>
-
- All Implemented Interfaces:
CheckpointableTask
,CoordinatedTask
,TaskInvokable
,AsyncExceptionHandler
,ContainingTaskDetails
- Direct Known Subclasses:
StreamIterationHead
,StreamIterationTail
@Internal public class OneInputStreamTask<IN,OUT> extends StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
AStreamTask
for executing aOneInputStreamOperator
.
-
-
Nested Class Summary
-
Nested classes/interfaces inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
StreamTask.CanEmitBatchOfRecordsChecker
-
-
Field Summary
-
Fields inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
-
-
Constructor Summary
Constructors Constructor Description OneInputStreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).OneInputStreamTask(Environment env, TimerService timeProvider)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected Optional<CheckpointBarrierHandler>
getCheckpointBarrierHandler()
Acquires the optionalCheckpointBarrierHandler
associated with this stream task.void
init()
-
Methods inherited from class org.apache.flink.streaming.runtime.tasks.StreamTask
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCanEmitBatchOfRecords, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, hasMail, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, notifyEndOfData, processInput, restore, runMailboxLoop, runMailboxStep, runSingleMailboxLoop, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
-
Methods inherited from class java.lang.Object
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
-
Methods inherited from interface org.apache.flink.streaming.runtime.tasks.ContainingTaskDetails
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
-
-
-
-
Constructor Detail
-
OneInputStreamTask
public OneInputStreamTask(Environment env) throws Exception
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).- Parameters:
env
- The task environment for this task.- Throws:
Exception
-
OneInputStreamTask
@VisibleForTesting public OneInputStreamTask(Environment env, @Nullable TimerService timeProvider) throws Exception
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).This constructor accepts a special
TimerService
. By default (and if null is passes for the time provider) aDefaultTimerService
will be used.- Parameters:
env
- The task environment for this task.timeProvider
- Optionally, a specific time provider to use.- Throws:
Exception
-
-
Method Detail
-
init
public void init() throws Exception
- Specified by:
init
in classStreamTask<OUT,OneInputStreamOperator<IN,OUT>>
- Throws:
Exception
-
getCheckpointBarrierHandler
protected Optional<CheckpointBarrierHandler> getCheckpointBarrierHandler()
Description copied from class:StreamTask
Acquires the optionalCheckpointBarrierHandler
associated with this stream task. TheCheckpointBarrierHandler
should exist if the task has data inputs and requires to align the barriers.- Overrides:
getCheckpointBarrierHandler
in classStreamTask<OUT,OneInputStreamOperator<IN,OUT>>
-
-