IN1
- first input typeIN2
- second input typepublic class PythonDualInputSender<IN1,IN2> extends PythonSender
PythonSender
for operations with two input streams.PythonSender.Serializer<T>
TYPE_ARRAY, TYPE_KEY_VALUE, TYPE_VALUE_VALUE
Modifier | Constructor and Description |
---|---|
protected |
PythonDualInputSender(Configuration config) |
Modifier and Type | Method and Description |
---|---|
int |
sendBuffer1(org.apache.flink.python.api.streaming.data.SingleElementPushBackIterator<IN1> input)
Extracts records from an iterator and writes them to the memory-mapped file.
|
int |
sendBuffer2(org.apache.flink.python.api.streaming.data.SingleElementPushBackIterator<IN2> input)
Extracts records from an iterator and writes them to the memory-mapped file.
|
close, getSerializer, open, sendBuffer
protected PythonDualInputSender(Configuration config)
public int sendBuffer1(org.apache.flink.python.api.streaming.data.SingleElementPushBackIterator<IN1> input) throws IOException
input
- iterator containing recordsIOException
public int sendBuffer2(org.apache.flink.python.api.streaming.data.SingleElementPushBackIterator<IN2> input) throws IOException
input
- iterator containing recordsIOException
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.