@Internal public class OneInputStreamTask<IN,OUT> extends StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
StreamTask
for executing a OneInputStreamOperator
.StreamTask.CanEmitBatchOfRecordsChecker
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
Constructor and 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).
|
Modifier and Type | Method and Description |
---|---|
protected Optional<CheckpointBarrierHandler> |
getCheckpointBarrierHandler()
Acquires the optional
CheckpointBarrierHandler associated with this stream task. |
void |
init() |
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, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, notifyEndOfData, processInput, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
public OneInputStreamTask(Environment env) throws Exception
env
- The task environment for this task.Exception
@VisibleForTesting public OneInputStreamTask(Environment env, @Nullable TimerService timeProvider) throws Exception
This constructor accepts a special TimerService
. By default (and if null is passes
for the time provider) a DefaultTimerService
will be
used.
env
- The task environment for this task.timeProvider
- Optionally, a specific time provider to use.Exception
public void init() throws Exception
init
in class StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
Exception
protected Optional<CheckpointBarrierHandler> getCheckpointBarrierHandler()
StreamTask
CheckpointBarrierHandler
associated with this stream task. The
CheckpointBarrierHandler
should exist if the task has data inputs and requires to
align the barriers.getCheckpointBarrierHandler
in class StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.