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 also keeps track of Watermark
events and forwards them to event subscribers
once the Watermark
from all inputs advances.
Forwarding elements or watermarks 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,
EventListener<CheckpointBarrier> checkpointListener,
CheckpointingMode checkpointMode,
IOManager ioManager,
boolean enableWatermarkMultiplexing) |
Modifier and Type | Method and Description |
---|---|
void |
cleanup() |
boolean |
processInput(TwoInputStreamOperator<IN1,IN2,?> streamOperator,
Object lock) |
void |
setReporter(AccumulatorRegistry.Reporter reporter) |
public StreamTwoInputProcessor(Collection<InputGate> inputGates1, Collection<InputGate> inputGates2, TypeSerializer<IN1> inputSerializer1, TypeSerializer<IN2> inputSerializer2, EventListener<CheckpointBarrier> checkpointListener, CheckpointingMode checkpointMode, IOManager ioManager, boolean enableWatermarkMultiplexing) throws IOException
IOException
public boolean processInput(TwoInputStreamOperator<IN1,IN2,?> streamOperator, Object lock) throws Exception
Exception
public void setReporter(AccumulatorRegistry.Reporter reporter)
public void cleanup() throws IOException
IOException
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.