@Internal public abstract class AbstractTwoInputStreamTask<IN1,IN2,OUT> extends StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
TwoInputStreamOperator.| Modifier and Type | Field and Description |
|---|---|
protected WatermarkGauge |
input1WatermarkGauge |
protected WatermarkGauge |
input2WatermarkGauge |
protected MinWatermarkGauge |
minInputWatermarkGauge |
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, systemTimerService, 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(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates1,
List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates2,
java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) |
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, assertTriggeringCheckpointExceptions, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, finishTask, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointBarrierHandler, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, processInput, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrierclone, equals, getClass, hashCode, notify, notifyAll, wait, wait, waitgetExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoaderprotected final WatermarkGauge input1WatermarkGauge
protected final WatermarkGauge input2WatermarkGauge
protected final MinWatermarkGauge minInputWatermarkGauge
public void init()
throws Exception
init in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>Exceptionprotected abstract void createInputProcessor(List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates1, List<org.apache.flink.runtime.io.network.partition.consumer.IndexedInputGate> inputGates2, java.util.function.Function<Integer,StreamPartitioner<?>> gatePartitioners) throws Exception
ExceptionCopyright © 2014–2021 The Apache Software Foundation. All rights reserved.