IN
- The type of the record that can be read with this record reader.@Internal public class StreamInputProcessor<IN> extends Object
OneInputStreamTask
.
This internally uses a StatusWatermarkValve
to keep track of Watermark
and
StreamStatus
events, and forwards them to event subscribers once the
StatusWatermarkValve
determines the Watermark
from all inputs has advanced, or
that a StreamStatus
needs to be propagated downstream to denote a status change.
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
OneInputStreamOperator
concurrently with the timer callback or other things.
Constructor and Description |
---|
StreamInputProcessor(InputGate[] inputGates,
TypeSerializer<IN> inputSerializer,
StreamTask<?,?> checkpointedTask,
CheckpointingMode checkpointMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
OneInputStreamOperator<IN,?> streamOperator,
TaskIOMetricGroup metrics,
WatermarkGauge watermarkGauge) |
public StreamInputProcessor(InputGate[] inputGates, TypeSerializer<IN> inputSerializer, StreamTask<?,?> checkpointedTask, CheckpointingMode checkpointMode, Object lock, IOManager ioManager, Configuration taskManagerConfig, StreamStatusMaintainer streamStatusMaintainer, OneInputStreamOperator<IN,?> streamOperator, TaskIOMetricGroup metrics, WatermarkGauge watermarkGauge) throws IOException
IOException
public void cleanup() throws IOException
IOException
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.