Interface TableSource<T>

  • Type Parameters:
    T - The return type of the TableSource.
    All Known Subinterfaces:
    LookupableTableSource<T>

    @Deprecated
    @Internal
    public interface 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 table with the schema that is provided by getTableSchema().

    The data of a TableSource is produced as a DataStream in case of a StreamTableSource. The type of this produced DataStream is specified by the getProducedDataType() method.

    By default, the fields of the TableSchema are implicitly mapped by name to the fields of the produced DataType. An explicit mapping can be defined by implementing the DefinedFieldMapping interface.

    • Method Detail

      • getProducedDataType

        default DataType getProducedDataType()
        Deprecated.
        Returns the DataType for the produced data of the TableSource.
        Returns:
        The data type of the returned DataStream.
      • getReturnType

        @Deprecated
        default org.apache.flink.api.common.typeinfo.TypeInformation<T> getReturnType()
        Deprecated.
        This method will be removed in future versions as it uses the old type system. It is recommended to use getProducedDataType() instead which uses the new type system based on DataTypes. Please make sure to use either the old or the new type system consistently to avoid unintended behavior. See the website documentation for more information.
      • getTableSchema

        @Deprecated
        TableSchema getTableSchema()
        Deprecated.
        Table schema is a logical description of a table and should not be part of the physical TableSource. Define schema when registering a Table either in DDL or in TableEnvironment#connect(...).
        Returns the schema of the produced table.
        Returns:
        The TableSchema of the produced table.
      • explainSource

        default String explainSource()
        Deprecated.
        Describes the table source.
        Returns:
        A String explaining the TableSource.