@Internal public class OneInputStreamTask<IN,OUT> extends StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
StreamTask
for executing a OneInputStreamOperator
.StreamTask.AsyncCheckpointRunnable
configuration, headOperator, inputProcessor, LOG, mailboxProcessor, 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, cancel, cancelTask, cleanup, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, finalize, finishTask, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getCompletionFuture, getConfiguration, getMailboxExecutorFactory, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, handleCheckpointException, invoke, isCanceled, isFailing, isRunning, notifyCheckpointCompleteAsync, processInput, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
public OneInputStreamTask(org.apache.flink.runtime.execution.Environment env)
env
- The task environment for this task.@VisibleForTesting public OneInputStreamTask(org.apache.flink.runtime.execution.Environment env, @Nullable TimerService timeProvider)
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.public void init() throws Exception
init
在类中 StreamTask<OUT,OneInputStreamOperator<IN,OUT>>
Exception
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.