public class CollectStreamTableSink extends Object implements org.apache.flink.table.sinks.RetractStreamTableSink<Row>
Constructor and Description |
---|
CollectStreamTableSink(InetAddress targetAddress,
int targetPort,
TypeSerializer<Tuple2<Boolean,Row>> serializer) |
Modifier and Type | Method and Description |
---|---|
org.apache.flink.table.sinks.TableSink<Tuple2<Boolean,Row>> |
configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes) |
void |
emitDataStream(DataStream<Tuple2<Boolean,Row>> stream) |
String[] |
getFieldNames() |
TypeInformation<?>[] |
getFieldTypes() |
TupleTypeInfo<Tuple2<Boolean,Row>> |
getOutputType() |
TypeInformation<Row> |
getRecordType() |
public CollectStreamTableSink(InetAddress targetAddress, int targetPort, TypeSerializer<Tuple2<Boolean,Row>> serializer)
public String[] getFieldNames()
public TypeInformation<?>[] getFieldTypes()
public org.apache.flink.table.sinks.TableSink<Tuple2<Boolean,Row>> configure(String[] fieldNames, TypeInformation<?>[] fieldTypes)
public TypeInformation<Row> getRecordType()
getRecordType
in interface org.apache.flink.table.sinks.RetractStreamTableSink<Row>
public void emitDataStream(DataStream<Tuple2<Boolean,Row>> stream)
emitDataStream
in interface org.apache.flink.table.sinks.RetractStreamTableSink<Row>
Copyright © 2014–2019 The Apache Software Foundation. All rights reserved.