@Internal public class TwoInputStreamTask<IN1,IN2,OUT> extends StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
StreamTask
for executing a TwoInputStreamOperator
.StreamTask.AsyncCheckpointRunnable
configuration, headOperator, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
TwoInputStreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
Modifier and Type | Method and Description |
---|---|
protected void |
cancelTask() |
protected void |
cleanup() |
void |
init() |
protected void |
run() |
abortCheckpointOnBarrier, cancel, createCheckpointExceptionHandlerFactory, createStreamRecordWriters, createStreamTaskStateInitializer, finalize, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, toString, triggerCheckpoint, triggerCheckpointOnBarrier
getCurrentNumberOfSubtasks, getEnvironment, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader
public TwoInputStreamTask(Environment env)
env
- The task environment for this task.public void init() throws Exception
init
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Exception
protected void run() throws Exception
run
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Exception
protected void cleanup() throws Exception
cleanup
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Exception
protected void cancelTask()
cancelTask
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.