Class InputFormatTableSource<T>

  • Type Parameters:
    T - Type of the bounded InputFormat created by this TableSource.
    All Implemented Interfaces:
    StreamTableSource<T>, org.apache.flink.table.legacy.sources.TableSource<T>

    @Deprecated
    @Internal
    public abstract class InputFormatTableSource<T>
    extends Object
    implements StreamTableSource<T>
    Deprecated.
    This interface has been replaced by DynamicTableSource. The new interface produces internal data structures. See FLIP-95 for more information.
    Defines an external bounded table and provides access to its data.
    • Constructor Detail

      • InputFormatTableSource

        public InputFormatTableSource()
        Deprecated.
    • Method Detail

      • getInputFormat

        public abstract org.apache.flink.api.common.io.InputFormat<T,​?> getInputFormat()
        Deprecated.
        Returns an InputFormat for reading the data of the table.
      • isBounded

        public final boolean isBounded()
        Deprecated.
        Always returns true which indicates this is a bounded source.
        Specified by:
        isBounded in interface StreamTableSource<T>
      • getDataStream

        public final org.apache.flink.streaming.api.datastream.DataStream<T> getDataStream​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
        Deprecated.
        Description copied from interface: StreamTableSource
        Returns the data of the table as a DataStream.

        NOTE: This method is for internal use only for defining a TableSource. Do not use it in Table API programs.

        Specified by:
        getDataStream in interface StreamTableSource<T>