@Internal public abstract class AbstractTwoInputStreamTask<IN1,IN2,OUT> extends StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
TwoInputStreamOperator
.StreamTask.ActionContext, StreamTask.AsyncCheckpointRunnable
Modifier and Type | Field and Description |
---|---|
protected WatermarkGauge |
input1WatermarkGauge |
protected WatermarkGauge |
input2WatermarkGauge |
protected MinWatermarkGauge |
minInputWatermarkGauge |
configuration, headOperator, inputProcessor, mailbox, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
AbstractTwoInputStreamTask(org.apache.flink.runtime.execution.Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
createInputProcessor(Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates1,
Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates2,
org.apache.flink.api.common.typeutils.TypeSerializer<IN1> inputDeserializer1,
org.apache.flink.api.common.typeutils.TypeSerializer<IN2> inputDeserializer2) |
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, cancel, cancelTask, cleanup, createCheckpointExceptionHandlerFactory, createRecordWriters, createStreamTaskStateInitializer, finalize, finishTask, getAccumulatorMap, getAsyncOperationsThreadPool, getCancelables, getCheckpointLock, getCheckpointStorage, getConfiguration, getName, getProcessingTimeService, getStreamStatusMaintainer, handleAsyncException, invoke, isCanceled, isRunning, notifyCheckpointComplete, processInput, toString, triggerCheckpoint, triggerCheckpointOnBarrier
getCurrentNumberOfSubtasks, getEnvironment, getExecutingThread, getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getTaskConfiguration, getUserCodeClassLoader, setShouldInterruptOnCancel, shouldInterruptOnCancel
protected final WatermarkGauge input1WatermarkGauge
protected final WatermarkGauge input2WatermarkGauge
protected final MinWatermarkGauge minInputWatermarkGauge
public AbstractTwoInputStreamTask(org.apache.flink.runtime.execution.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 abstract void createInputProcessor(Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates1, Collection<org.apache.flink.runtime.io.network.partition.consumer.InputGate> inputGates2, org.apache.flink.api.common.typeutils.TypeSerializer<IN1> inputDeserializer1, org.apache.flink.api.common.typeutils.TypeSerializer<IN2> inputDeserializer2) throws Exception
Exception
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.