Interface StreamTableSource<T>

  • Type Parameters:
    T - Type of the DataStream created by this TableSource.
    All Superinterfaces:
    org.apache.flink.table.legacy.sources.TableSource<T>
    All Known Implementing Classes:
    CsvTableSource, InputFormatTableSource

    @Deprecated
    @Internal
    public interface StreamTableSource<T>
    extends org.apache.flink.table.legacy.sources.TableSource<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 stream table and provides read access to its data.
    • Method Summary

      All Methods Instance Methods Abstract Methods Default Methods Deprecated Methods 
      Modifier and Type Method Description
      org.apache.flink.streaming.api.datastream.DataStream<T> getDataStream​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
      Deprecated.
      Returns the data of the table as a DataStream.
      default boolean isBounded()
      Deprecated.
      Returns true if this is a bounded source, false if this is an unbounded source.
      • Methods inherited from interface org.apache.flink.table.legacy.sources.TableSource

        explainSource, getProducedDataType, getReturnType, getTableSchema
    • Method Detail

      • isBounded

        default boolean isBounded()
        Deprecated.
        Returns true if this is a bounded source, false if this is an unbounded source. Default is unbounded for compatibility.
      • getDataStream

        org.apache.flink.streaming.api.datastream.DataStream<T> getDataStream​(org.apache.flink.streaming.api.environment.StreamExecutionEnvironment execEnv)
        Deprecated.
        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.