@Internal public abstract class AbstractTwoInputStreamTask<IN1,IN2,OUT> extends StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
TwoInputStreamOperator
.限定符和类型 | 字段和说明 |
---|---|
protected WatermarkGauge |
input1WatermarkGauge |
protected WatermarkGauge |
input2WatermarkGauge |
protected MinWatermarkGauge |
minInputWatermarkGauge |
configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, stateBackend, timerService, TRIGGER_THREAD_GROUP
构造器和说明 |
---|
AbstractTwoInputStreamTask(org.apache.flink.runtime.execution.Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
限定符和类型 | 方法和说明 |
---|---|
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) |
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, triggerCheckpointOnBarrier
protected final WatermarkGauge input1WatermarkGauge
protected final WatermarkGauge input2WatermarkGauge
protected final MinWatermarkGauge minInputWatermarkGauge
public void init() throws Exception
init
在类中 StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Exception
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.