@Internal public abstract class AbstractTwoInputStreamTask<IN1,IN2,OUT> extends StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
TwoInputStreamOperator
.StreamTask.CanEmitBatchOfRecordsChecker
Modifier and Type | Field and Description |
---|---|
protected WatermarkGauge |
input1WatermarkGauge |
protected WatermarkGauge |
input2WatermarkGauge |
protected MinWatermarkGauge |
minInputWatermarkGauge |
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
AbstractTwoInputStreamTask(Environment env)
Constructor for initialization, possibly with initial state (recovery / savepoint / etc).
|
Modifier and Type | Method and Description |
---|---|
protected abstract void |
createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
Function<Integer,StreamPartitioner<?>> gatePartitioners) |
void |
init() |
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCanEmitBatchOfRecords, getCheckpointBarrierHandler, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, hasMail, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, notifyEndOfData, processInput, restore, runMailboxLoop, runMailboxStep, runSingleMailboxLoop, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
protected final WatermarkGauge input1WatermarkGauge
protected final WatermarkGauge input2WatermarkGauge
protected final MinWatermarkGauge minInputWatermarkGauge
public AbstractTwoInputStreamTask(Environment env) throws Exception
env
- The task environment for this task.Exception
public void init() throws Exception
init
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Exception
protected abstract void createInputProcessor(List<IndexedInputGate> inputGates1, List<IndexedInputGate> inputGates2, Function<Integer,StreamPartitioner<?>> gatePartitioners) throws Exception
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.