Interface TableSink<T>

  • Type Parameters:
    T - The return type of the TableSink.
    All Known Implementing Classes:
    TableSinkBase

    @Deprecated
    @Internal
    public interface TableSink<T>
    Deprecated.
    This interface has been replaced by DynamicTableSink. The new interface consumes internal data structures. See FLIP-95 for more information.
    A TableSink specifies how to emit a table to an external system or location.

    The interface is generic such that it can support different storage locations and formats.

    • Method Detail

      • getConsumedDataType

        default DataType getConsumedDataType()
        Deprecated.
        Returns the data type consumed by this TableSink.
        Returns:
        The data type expected by this TableSink.
      • getOutputType

        @Deprecated
        default org.apache.flink.api.common.typeinfo.TypeInformation<T> getOutputType()
        Deprecated.
        This method will be removed in future versions as it uses the old type system. It is recommended to use getConsumedDataType() 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

        default TableSchema getTableSchema()
        Deprecated.
        Returns the schema of the consumed table.
        Returns:
        The TableSchema of the consumed table.
      • getFieldTypes

        @Deprecated
        default org.apache.flink.api.common.typeinfo.TypeInformation<?>[] getFieldTypes()
        Deprecated.
        Use the field types of getTableSchema() instead.
      • configure

        @Deprecated
        TableSink<T> configure​(String[] fieldNames,
                               org.apache.flink.api.common.typeinfo.TypeInformation<?>[] fieldTypes)
        Deprecated.
        This method will be dropped in future versions. It is recommended to pass a static schema when instantiating the sink instead.
        Returns a copy of this TableSink configured with the field names and types of the table to emit.
        Parameters:
        fieldNames - The field names of the table to emit.
        fieldTypes - The field types of the table to emit.
        Returns:
        A copy of this TableSink configured with the field names and types of the table to emit.