@Internal public class TwoInputStreamTask<IN1,IN2,OUT> extends AbstractTwoInputStreamTask<IN1,IN2,OUT>
StreamTask
for executing a TwoInputStreamOperator
and supporting the TwoInputStreamOperator
to select input for reading.StreamTask.CanEmitBatchOfRecordsChecker
input1WatermarkGauge, input2WatermarkGauge, minInputWatermarkGauge
checkpointStorage, configuration, inputProcessor, LOG, mailboxProcessor, mainOperator, operatorChain, recordWriter, stateBackend, systemTimerService, timerService, TRIGGER_THREAD_GROUP
Constructor and Description |
---|
TwoInputStreamTask(Environment env) |
Modifier and Type | Method and Description |
---|---|
protected void |
createInputProcessor(List<IndexedInputGate> inputGates1,
List<IndexedInputGate> inputGates2,
Function<Integer,StreamPartitioner<?>> gatePartitioners) |
StreamTask.CanEmitBatchOfRecordsChecker |
getCanEmitBatchOfRecords() |
protected Optional<CheckpointBarrierHandler> |
getCheckpointBarrierHandler()
Acquires the optional
CheckpointBarrierHandler associated with this stream task. |
init
abortCheckpointOnBarrier, advanceToEndOfEventTime, afterInvoke, cancel, cancelTask, cleanUp, cleanUpInternal, createRecordWriterDelegate, createStreamTaskStateInitializer, declineCheckpoint, dispatchOperatorEvent, endData, finalize, getAsyncCheckpointStartDelayNanos, getAsyncOperationsThreadPool, getCancelables, getCheckpointStorage, getCompletionFuture, getConfiguration, getEnvironment, getMailboxExecutorFactory, getName, getProcessingTimeServiceFactory, handleAsyncException, invoke, isCanceled, isFailing, isMailboxLoopRunning, isRunning, isUsingNonBlockingInput, maybeInterruptOnCancel, notifyCheckpointAbortAsync, notifyCheckpointCompleteAsync, notifyCheckpointSubsumedAsync, notifyEndOfData, processInput, restore, runMailboxLoop, runMailboxStep, setSynchronousSavepoint, setupNumRecordsInCounter, toString, triggerCheckpointAsync, triggerCheckpointOnBarrier
clone, equals, getClass, hashCode, notify, notifyAll, wait, wait, wait
getExecutionConfig, getIndexInSubtaskGroup, getJobConfiguration, getUserCodeClassLoader
public TwoInputStreamTask(Environment env) throws Exception
Exception
protected Optional<CheckpointBarrierHandler> getCheckpointBarrierHandler()
StreamTask
CheckpointBarrierHandler
associated with this stream task. The
CheckpointBarrierHandler
should exist if the task has data inputs and requires to
align the barriers.getCheckpointBarrierHandler
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
protected void createInputProcessor(List<IndexedInputGate> inputGates1, List<IndexedInputGate> inputGates2, Function<Integer,StreamPartitioner<?>> gatePartitioners)
createInputProcessor
in class AbstractTwoInputStreamTask<IN1,IN2,OUT>
public StreamTask.CanEmitBatchOfRecordsChecker getCanEmitBatchOfRecords()
getCanEmitBatchOfRecords
in class StreamTask<OUT,TwoInputStreamOperator<IN1,IN2,OUT>>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.