Class OutputFormatTableSink<T>
- java.lang.Object
-
- org.apache.flink.legacy.table.sinks.OutputFormatTableSink<T>
-
- Type Parameters:
T- Type of the boundedOutputFormatthat thisTableSinkexpects and supports.
- All Implemented Interfaces:
StreamTableSink<T>,org.apache.flink.table.legacy.sinks.TableSink<T>
@Deprecated @Internal public abstract class OutputFormatTableSink<T> extends Object implements StreamTableSink<T>
Deprecated.This interface has been replaced byDynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information.Defines an externalTableSinkto emit a boundedTable.
-
-
Constructor Summary
Constructors Constructor Description OutputFormatTableSink()Deprecated.
-
Method Summary
All Methods Instance Methods Abstract Methods Concrete Methods Deprecated Methods Modifier and Type Method Description org.apache.flink.streaming.api.datastream.DataStreamSink<T>consumeDataStream(org.apache.flink.streaming.api.datastream.DataStream<T> dataStream)Deprecated.Consumes the DataStream and return the sink transformationDataStreamSink.abstract org.apache.flink.api.common.io.OutputFormat<T>getOutputFormat()Deprecated.Returns anOutputFormatfor writing the data of the table.
-
-
-
Method Detail
-
getOutputFormat
public abstract org.apache.flink.api.common.io.OutputFormat<T> getOutputFormat()
Deprecated.Returns anOutputFormatfor writing the data of the table.
-
consumeDataStream
public final org.apache.flink.streaming.api.datastream.DataStreamSink<T> consumeDataStream(org.apache.flink.streaming.api.datastream.DataStream<T> dataStream)
Deprecated.Description copied from interface:StreamTableSinkConsumes the DataStream and return the sink transformationDataStreamSink. The returnedDataStreamSinkwill be used to set resources for the sink operator.- Specified by:
consumeDataStreamin interfaceStreamTableSink<T>
-
-