IN1
- The type of the records that arrive on the first inputIN2
- The type of the records that arrive on the second input@Internal public class StreamTwoInputProcessor<IN1,IN2> extends Object
TwoInputStreamTask
.
This internally uses a StatusWatermarkValve
to keep track of Watermark
and
StreamStatus
events, and forwards watermarks to event subscribers once the
StatusWatermarkValve
determines the watermarks from all inputs has advanced, or changes
the task's StreamStatus
once status change is toggled.
Forwarding elements, watermarks, or status status elements must be protected by synchronizing
on the given lock object. This ensures that we don't call methods on a
TwoInputStreamOperator
concurrently with the timer callback or other things.
Constructor and Description |
---|
StreamTwoInputProcessor(Collection<InputGate> inputGates1,
Collection<InputGate> inputGates2,
TypeSerializer<IN1> inputSerializer1,
TypeSerializer<IN2> inputSerializer2,
TwoInputStreamTask<IN1,IN2,?> checkpointedTask,
CheckpointingMode checkpointMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
TaskIOMetricGroup metrics,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge) |
public StreamTwoInputProcessor(Collection<InputGate> inputGates1, Collection<InputGate> inputGates2, TypeSerializer<IN1> inputSerializer1, TypeSerializer<IN2> inputSerializer2, TwoInputStreamTask<IN1,IN2,?> checkpointedTask, CheckpointingMode checkpointMode, Object lock, IOManager ioManager, Configuration taskManagerConfig, StreamStatusMaintainer streamStatusMaintainer, TwoInputStreamOperator<IN1,IN2,?> streamOperator, TaskIOMetricGroup metrics, WatermarkGauge input1WatermarkGauge, WatermarkGauge input2WatermarkGauge) throws IOException
IOException
public void cleanup() throws IOException
IOException
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.