Class OutputFormatTableSink<T>

  • Type Parameters:
    T - Type of the bounded OutputFormat that this TableSink expects 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 by DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information.
    Defines an external TableSink to emit a bounded Table.
    • Constructor Detail

      • OutputFormatTableSink

        public OutputFormatTableSink()
        Deprecated.
    • Method Detail

      • getOutputFormat

        public abstract org.apache.flink.api.common.io.OutputFormat<T> getOutputFormat()
        Deprecated.
        Returns an OutputFormat for 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: StreamTableSink
        Consumes the DataStream and return the sink transformation DataStreamSink. The returned DataStreamSink will be used to set resources for the sink operator.
        Specified by:
        consumeDataStream in interface StreamTableSink<T>