@Internal public class OneInputStreamTask<IN,OUT> extends StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
StreamTask for executing a OneInputStreamOperator.configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP| 构造器和说明 |
|---|
OneInputStreamTask(org.apache.flink.runtime.execution.Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
OneInputStreamTask(org.apache.flink.runtime.execution.Environment env,
TimerService timeProvider)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
| 限定符和类型 | 方法和说明 |
|---|---|
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, beforeInvoke, cancel, cancelTask, cleanup, cleanUpInvoke, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, runMailboxLoop, runMailboxStep, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrierpublic OneInputStreamTask(org.apache.flink.runtime.execution.Environment env)
throws Exception
env - The task environment for this task.Exception@VisibleForTesting
public OneInputStreamTask(org.apache.flink.runtime.execution.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.Exceptionpublic void init()
throws Exception
init 在类中 StreamTask<OUT,OneInputStreamOperator<IN,OUT>>ExceptionCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.