Class TableSchema


  • @Deprecated
    @Internal
    public class TableSchema
    extends Object
    Deprecated.
    This class has been deprecated as part of FLIP-164. It has been replaced by two more dedicated classes Schema and ResolvedSchema. Use Schema for declaration in APIs. ResolvedSchema is offered by the framework after resolution and validation.
    A table schema that represents a table's structure with field names and data types.
    • Constructor Detail

      • TableSchema

        @Deprecated
        public TableSchema​(String[] fieldNames,
                           org.apache.flink.api.common.typeinfo.TypeInformation<?>[] fieldTypes)
        Deprecated.
        Use the TableSchema.Builder instead.
    • Method Detail

      • copy

        public TableSchema copy()
        Deprecated.
        Returns a deep copy of the table schema.
      • getFieldDataTypes

        public DataType[] getFieldDataTypes()
        Deprecated.
        Returns all field data types as an array.
      • getFieldTypes

        @Deprecated
        public org.apache.flink.api.common.typeinfo.TypeInformation<?>[] getFieldTypes()
        Deprecated.
        This method will be removed in future versions as it uses the old type system. It is recommended to use getFieldDataTypes() 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.
      • getFieldDataType

        public Optional<DataType> getFieldDataType​(int fieldIndex)
        Deprecated.
        Returns the specified data type for the given field index.
        Parameters:
        fieldIndex - the index of the field
      • getFieldType

        @Deprecated
        public Optional<org.apache.flink.api.common.typeinfo.TypeInformation<?>> getFieldType​(int fieldIndex)
        Deprecated.
        This method will be removed in future versions as it uses the old type system. It is recommended to use getFieldDataType(int) 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.
      • getFieldDataType

        public Optional<DataType> getFieldDataType​(String fieldName)
        Deprecated.
        Returns the specified data type for the given field name.
        Parameters:
        fieldName - the name of the field
      • getFieldType

        @Deprecated
        public Optional<org.apache.flink.api.common.typeinfo.TypeInformation<?>> getFieldType​(String fieldName)
        Deprecated.
        This method will be removed in future versions as it uses the old type system. It is recommended to use getFieldDataType(String) 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.
      • getFieldCount

        public int getFieldCount()
        Deprecated.
        Returns the number of fields.
      • getFieldNames

        public String[] getFieldNames()
        Deprecated.
        Returns all field names as an array.
      • getFieldName

        public Optional<String> getFieldName​(int fieldIndex)
        Deprecated.
        Returns the specified name for the given field index.
        Parameters:
        fieldIndex - the index of the field
      • getTableColumn

        public Optional<TableColumn> getTableColumn​(int fieldIndex)
        Deprecated.
        Returns the TableColumn instance for the given field index.
        Parameters:
        fieldIndex - the index of the field
      • getTableColumn

        public Optional<TableColumn> getTableColumn​(String fieldName)
        Deprecated.
        Returns the TableColumn instance for the given field name.
        Parameters:
        fieldName - the name of the field
      • toPhysicalRowDataType

        public DataType toPhysicalRowDataType()
        Deprecated.
        Converts all physical columns of this schema into a (possibly nested) row data type.

        Note: The returned row data type contains only physical columns. It does not include computed or metadata columns.

        See Also:
        DataTypes.ROW(Field...), toRowDataType(), toPersistedRowDataType()
      • toPersistedRowDataType

        public DataType toPersistedRowDataType()
        Deprecated.
        Converts all persisted columns of this schema into a (possibly nested) row data type.

        This method returns the query-to-sink schema.

        Note: Computed columns and virtual columns are excluded in the returned row data type. The data type contains the columns of toPhysicalRowDataType() plus persisted metadata columns.

        See Also:
        DataTypes.ROW(Field...), toRowDataType(), toPhysicalRowDataType()
      • toRowType

        @Deprecated
        public org.apache.flink.api.common.typeinfo.TypeInformation<org.apache.flink.types.Row> toRowType()
        Deprecated.
        Use toRowDataType() instead.
      • getWatermarkSpecs

        public List<WatermarkSpec> getWatermarkSpecs()
        Deprecated.
        Returns a list of the watermark specification which contains rowtime attribute and watermark strategy expression.

        NOTE: Currently, there is at most one WatermarkSpec in the list, because we don't support multiple watermarks definition yet. But in the future, we may support multiple watermarks.

      • toSchema

        public Schema toSchema()
        Deprecated.
        Helps to migrate to the new Schema class.
      • toSchema

        public Schema toSchema​(Map<String,​String> comments)
        Deprecated.
        Helps to migrate to the new Schema class, retain comments when needed.
      • equals

        public boolean equals​(Object o)
        Deprecated.
        Overrides:
        equals in class Object
      • hashCode

        public int hashCode()
        Deprecated.
        Overrides:
        hashCode in class Object
      • fromTypeInfo

        @Deprecated
        public static TableSchema fromTypeInfo​(org.apache.flink.api.common.typeinfo.TypeInformation<?> typeInfo)
        Deprecated.
        This method will be removed soon. Use DataTypes to declare types.
        Creates a table schema from a TypeInformation instance. If the type information is a CompositeType, the field names and types for the composite type are used to construct the TableSchema instance. Otherwise, a table schema with a single field is created. The field name is "f0" and the field type the provided type.
        Parameters:
        typeInfo - The TypeInformation from which the table schema is generated.
        Returns:
        The table schema that was generated from the given TypeInformation.