public class CollectBatchTableSink extends OutputFormatTableSink<Row> implements BatchTableSink<Row>
Constructor and Description |
---|
CollectBatchTableSink(String accumulatorName,
TypeSerializer<Row> serializer,
TableSchema tableSchema) |
Modifier and Type | Method and Description |
---|---|
CollectBatchTableSink |
configure(String[] fieldNames,
TypeInformation<?>[] fieldTypes)
Returns a copy of this
TableSink configured with the field names and types of the
table to emit. |
DataSink<?> |
consumeDataSet(DataSet<Row> dataSet)
Consumes the DataSet and return the
DataSink . |
DataType |
getConsumedDataType()
Returns the data type consumed by this
TableSink . |
OutputFormat<Row> |
getOutputFormat()
Returns an
OutputFormat for writing the data of the table. |
TypeSerializer<Row> |
getSerializer()
Returns the serializer for deserializing the collected result.
|
TableSchema |
getTableSchema()
Returns the schema of the consumed table.
|
consumeDataStream
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
getFieldNames, getFieldTypes, getOutputType
public CollectBatchTableSink(String accumulatorName, TypeSerializer<Row> serializer, TableSchema tableSchema)
public TypeSerializer<Row> getSerializer()
public DataType getConsumedDataType()
TableSink
TableSink
.getConsumedDataType
in interface TableSink<Row>
TableSink
.public TableSchema getTableSchema()
TableSink
getTableSchema
in interface TableSink<Row>
TableSchema
of the consumed table.public CollectBatchTableSink configure(String[] fieldNames, TypeInformation<?>[] fieldTypes)
TableSink
TableSink
configured with the field names and types of the
table to emit.public DataSink<?> consumeDataSet(DataSet<Row> dataSet)
BatchTableSink
consumeDataSet
in interface BatchTableSink<Row>
public OutputFormat<Row> getOutputFormat()
OutputFormatTableSink
OutputFormat
for writing the data of the table.getOutputFormat
in class OutputFormatTableSink<Row>
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.