@Internal public class RecordWriterOutput<OUT> extends Object implements Output<StreamRecord<OUT>>
Output
that sends data using a RecordWriter
.Constructor and Description |
---|
RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter,
TypeSerializer<OUT> outSerializer,
boolean enableWatermarkMultiplexing) |
Modifier and Type | Method and Description |
---|---|
void |
broadcastEvent(AbstractEvent barrier) |
void |
clearBuffers() |
void |
close()
Closes the collector.
|
void |
collect(StreamRecord<OUT> record)
Emits a record.
|
void |
emitWatermark(Watermark mark)
Emits a
Watermark from an operator. |
void |
flush() |
public RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>> recordWriter, TypeSerializer<OUT> outSerializer, boolean enableWatermarkMultiplexing)
public void collect(StreamRecord<OUT> record)
Collector
collect
in interface Collector<StreamRecord<OUT>>
record
- The record to collect.public void emitWatermark(Watermark mark)
Output
Watermark
from an operator. This watermark is broadcast to all downstream
operators.
A watermark specifies that no element with a timestamp lower or equal to the watermark timestamp will be emitted in the future.
emitWatermark
in interface Output<StreamRecord<OUT>>
public void broadcastEvent(AbstractEvent barrier) throws IOException, InterruptedException
IOException
InterruptedException
public void flush() throws IOException
IOException
public void close()
Collector
close
in interface Collector<StreamRecord<OUT>>
public void clearBuffers()
Copyright © 2014–2017 The Apache Software Foundation. All rights reserved.