@Internal public class OneInputStreamTask<IN,OUT> extends StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
StreamTask
for executing a OneInputStreamOperator
.configuration, headOperator, inputProcessor, LOG, mailboxProcessor, operatorChain, stateBackend, 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 |
---|---|
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, beforeInvoke, cancel, cancelTask, cleanup, cleanUpInvoke, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, executeInTaskThread, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, runMailboxStep, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
getCurrentNumberOfSubtasks, getEnvironment, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, setShouldInterruptOnCancel, shouldInterruptOnCancel
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
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.