Uses of Package
org.apache.flink.table.catalog
-
Classes in org.apache.flink.table.catalog used by org.apache.flink.connector.file.table Class Description ObjectIdentifier Identifies an object in a catalog.ObjectPath A database name and object (table/view/function) name combo in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.connector.file.table.batch Class Description ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.connector.file.table.batch.compact Class Description ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.connector.file.table.stream Class Description ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.api Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogDescriptor Describes aCatalog
with the catalog name and configuration.CatalogStore Represents the storage where persists allCatalog
s.CatalogTable Represents the unresolved metadata of a table in aCatalog
.ObjectIdentifier Identifies an object in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.SchemaResolver Resolves aSchema
to a validatedResolvedSchema
.TableDistribution Defines whether the given table is distributed across buckets using a specified algorithm and given columns. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.api.bridge.internal Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.ObjectIdentifier Identifies an object in a catalog.SchemaTranslator.ProducingResult -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.api.bridge.java.internal Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.api.internal Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogBaseTable A common parent that describes the unresolved metadata of a table or view in a catalog.CatalogDescriptor Describes aCatalog
with the catalog name and configuration.CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.FunctionLookup Catalog of functions that can resolve the name of a function to aContextResolvedFunction
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogBaseTable A common parent that describes the resolved metadata of a table or view in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.calcite.bridge Class Description FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.catalog Class Description AbstractCatalog Abstract class for catalogs.AbstractCatalogStore The AbstractCatalogStore class is an abstract base class for implementing a catalog store.AbstractCatalogTable An abstract catalog table.AbstractCatalogView An abstract catalog view.Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogBaseTable A common parent that describes the unresolved metadata of a table or view in a catalog.CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.CatalogChange CatalogChange
represents the modification of the catalog.CatalogDatabase Interface of a database in a catalog.CatalogDescriptor Describes aCatalog
with the catalog name and configuration.CatalogFunction Interface for a function in a catalog.CatalogLock Deprecated.This interface will be removed soon.CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogManager.Builder Builder for a fluent definition of aCatalogManager
.CatalogMaterializedTable Represents the unresolved metadata of a materialized table in aCatalog
.CatalogMaterializedTable.Builder Builder for configuring and creating instances ofCatalogMaterializedTable
.CatalogMaterializedTable.LogicalRefreshMode The logical refresh mode of materialized table.CatalogMaterializedTable.RefreshMode The physical refresh mode of materialized table.CatalogMaterializedTable.RefreshStatus Background refresh pipeline status of materialized table.CatalogModel Interface for a model in a catalog.CatalogPartition Represents a partition object in catalog.CatalogPartitionSpec Represents a partition spec object in catalog.CatalogRegistry A catalog registry for dealing with catalogs.CatalogStore Represents the storage where persists allCatalog
s.CatalogStoreHolder A holder for aCatalogStore
instance and the necessary information for creating and initializingCatalog
instances, including aCatalogStoreFactory
, aReadableConfig
instance, and aClassLoader
instance.CatalogStoreHolder.Builder Builder for a fluent definition of aCatalogStoreHolder
.CatalogTable Represents the unresolved metadata of a table in aCatalog
.CatalogTable.Builder Builder for configuring and creating instances ofCatalogTable
.CatalogTableImpl Deprecated.UseCatalogTable.of(Schema, String, List, Map)
or a custom implementation instead.CatalogView Represents the unresolved metadata of a view in aCatalog
.Column Representation of a column in aResolvedSchema
.Column.ComputedColumn Representation of a computed column.Column.MetadataColumn Representation of a metadata column.Column.PhysicalColumn Representation of a physical column.ConnectorCatalogTable Constraint Integrity constraints, generally referred to simply as constraints, define the valid states of SQL-data by constraining the values in the base tables.Constraint.ConstraintType Type of the constraint.ContextResolvedFunction This class contains information about a function and its relationship with aCatalog
, if any.ContextResolvedModel This class contains information about a model and its relationship with aCatalog
, if any.ContextResolvedProcedure This class contains information about a procedure and its relationship with aCatalog
.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.FunctionLanguage Categorizes the language semantics of aCatalogFunction
.FunctionLookup Catalog of functions that can resolve the name of a function to aContextResolvedFunction
.IntervalFreshness TheIntervalFreshness
represents freshness definition ofCatalogMaterializedTable
.IntervalFreshness.TimeUnit An enumeration of time unit representing the unit of interval freshness.ObjectIdentifier Identifies an object in a catalog.ObjectPath A database name and object (table/view/function) name combo in a catalog.QueryOperationCatalogView A view created from aQueryOperation
via operations onTable
.ResolvedCatalogBaseTable A common parent that describes the resolved metadata of a table or view in a catalog.ResolvedCatalogMaterializedTable A validatedCatalogMaterializedTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedCatalogModel A validatedCatalogModel
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedCatalogView A validatedCatalogView
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.SchemaResolver Resolves aSchema
to a validatedResolvedSchema
.SchemaTranslator.ConsumingResult SchemaTranslator.ProducingResult TableChange TableChange
represents the modification of the table.TableChange.AddColumn A table change to add a column.TableChange.AddDistribution A table change to add a distribution.TableChange.AddUniqueConstraint A table change to add a unique constraint.TableChange.AddWatermark A table change to add a watermark.TableChange.ColumnPosition The position of the modified or added column.TableChange.DropColumn A table change to drop the column.TableChange.DropConstraint A table change to drop the constraints.TableChange.DropDistribution A table change to drop a table's distribution.TableChange.DropWatermark A table change to drop the watermark.TableChange.MaterializedTableChange TableChange.MaterializedTableChange
represents the modification of the materialized table.TableChange.ModifyColumn A base schema change to modify a column.TableChange.ModifyColumnComment A table change to modify the column comment.TableChange.ModifyColumnName A table change to modify the column name.TableChange.ModifyColumnPosition A table change to modify the column position.TableChange.ModifyDistribution A table change to modify a distribution.TableChange.ModifyPhysicalColumnType A table change that modify the physical column data type.TableChange.ModifyRefreshHandler A table change to modify materialized table refresh handler.TableChange.ModifyRefreshStatus A table change to modify materialized table refresh status.TableChange.ModifyUniqueConstraint A table change to modify a unique constraint.TableChange.ModifyWatermark A table change to modify the watermark.TableChange.ResetOption A table change to reset the table option.TableChange.SetOption A table change to set the table option.TableDistribution Defines whether the given table is distributed across buckets using a specified algorithm and given columns.TableDistribution.Kind Distribution kind.TemporaryOperationListener This interface is for aCatalog
to listen on temporary object operations.UniqueConstraint A unique key constraint.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog.WatermarkSpec Representation of a watermark specification in aResolvedSchema
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.catalog.exceptions Class Description CatalogPartitionSpec Represents a partition spec object in catalog.ObjectPath A database name and object (table/view/function) name combo in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.catalog.listener Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogBaseTable A common parent that describes the unresolved metadata of a table or view in a catalog.CatalogDatabase Interface of a database in a catalog.CatalogModel Interface for a model in a catalog.ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.client.gateway Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.connector Class Description CatalogLock.Factory Deprecated.This interface will be removed soon. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.connector.sink.abilities Class Description Column Representation of a column in aResolvedSchema
.StagedTable TheStagedTable
is designed to implement Flink's atomic semantic for CTAS(CREATE TABLE AS SELECT) and RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit protocol.TableDistribution.Kind Distribution kind. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.delegation Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogRegistry A catalog registry for dealing with catalogs.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.examples.java.functions Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.execution Class Description StagedTable TheStagedTable
is designed to implement Flink's atomic semantic for CTAS(CREATE TABLE AS SELECT) and RTAS([CREATE OR] REPLACE TABLE AS SELECT) statement using a two-phase commit protocol. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.expressions Class Description ContextResolvedFunction This class contains information about a function and its relationship with aCatalog
, if any. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.expressions.resolver Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning.FunctionLookup Catalog of functions that can resolve the name of a function to aContextResolvedFunction
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.expressions.resolver.lookups Class Description Column Representation of a column in aResolvedSchema
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.expressions.resolver.rules Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning.FunctionLookup Catalog of functions that can resolve the name of a function to aContextResolvedFunction
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.factories Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogFunction Interface for a function in a catalog.CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogPartitionSpec Represents a partition spec object in catalog.CatalogStore Represents the storage where persists allCatalog
s.CatalogTable Represents the unresolved metadata of a table in aCatalog
.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.file.testutils.catalog Class Description AbstractCatalog Abstract class for catalogs.Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogBaseTable A common parent that describes the unresolved metadata of a table or view in a catalog.CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.CatalogDatabase Interface of a database in a catalog.CatalogFunction Interface for a function in a catalog.CatalogPartition Represents a partition object in catalog.CatalogPartitionSpec Represents a partition spec object in catalog.ObjectPath A database name and object (table/view/function) name combo in a catalog.TableChange TableChange
represents the modification of the table. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.functions Class Description CatalogFunction Interface for a function in a catalog.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.functions.python Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.api Class Description CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogBaseTable A common parent that describes the resolved metadata of a table or view in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.api.results Class Description CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.ObjectIdentifier Identifies an object in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.api.session Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.rest.serde Class Description Column Representation of a column in aResolvedSchema
.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.service Class Description CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogBaseTable A common parent that describes the resolved metadata of a table or view in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.service.context Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.service.materializedtable Class Description ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.service.operation Class Description CatalogBaseTable.TableKind The kind ofCatalogBaseTable
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogBaseTable A common parent that describes the resolved metadata of a table or view in a catalog.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.gateway.service.result Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.jdbc Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.legacy.api Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.legacy.factories Class Description CatalogTable Represents the unresolved metadata of a table in aCatalog
.ObjectIdentifier Identifies an object in a catalog.ObjectPath A database name and object (table/view/function) name combo in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.legacy.operations.ddl Class Description CatalogTable Represents the unresolved metadata of a table in aCatalog
.ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.operations Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogPartitionSpec Represents a partition spec object in catalog.ContextResolvedFunction This class contains information about a function and its relationship with aCatalog
, if any.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.operations.ddl Class Description CatalogDatabase Interface of a database in a catalog.CatalogFunction Interface for a function in a catalog.CatalogPartition Represents a partition object in catalog.CatalogPartitionSpec Represents a partition spec object in catalog.CatalogTable Represents the unresolved metadata of a table in aCatalog
.CatalogView Represents the unresolved metadata of a view in aCatalog
.Column Representation of a column in aResolvedSchema
.FunctionLanguage Categorizes the language semantics of aCatalogFunction
.ObjectIdentifier Identifies an object in a catalog.TableChange TableChange
represents the modification of the table. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.operations.materializedtable Class Description CatalogMaterializedTable Represents the unresolved metadata of a materialized table in aCatalog
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogMaterializedTable A validatedCatalogMaterializedTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.TableChange TableChange
represents the modification of the table. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.operations.utils Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.FunctionLookup Catalog of functions that can resolve the name of a function to aContextResolvedFunction
.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.calcite Class Description ObjectIdentifier Identifies an object in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.catalog Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogView Represents the unresolved metadata of a view in aCatalog
.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.QueryOperationCatalogView A view created from aQueryOperation
via operations onTable
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.connectors Class Description Catalog This interface is responsible for reading and writing metadata such as database/table/views/UDFs from a registered catalog.Column.MetadataColumn Representation of a metadata column.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.delegation Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.CatalogRegistry A catalog registry for dealing with catalogs.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.expressions Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.expressions.converter Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.functions.bridging Class Description ContextResolvedFunction This class contains information about a function and its relationship with aCatalog
, if any.ContextResolvedProcedure This class contains information about a procedure and its relationship with aCatalog
.DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.functions.inference Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.lineage Class Description CatalogBaseTable A common parent that describes the unresolved metadata of a table or view in a catalog.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.ObjectPath A database name and object (table/view/function) name combo in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.operations Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any.DataTypeFactory Factory for creating fully resolved data types that can be used for planning.ObjectIdentifier Identifies an object in a catalog.ResolvedCatalogTable A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.operations.converters Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.abilities.sink Class Description Column Representation of a column in aResolvedSchema
. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.abilities.source Class Description CatalogManager A manager for dealing with catalog objects such as tables, views, functions, and types.FunctionCatalog Simple function catalog to storeFunctionDefinition
s in catalogs. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.nodes.exec.batch Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.nodes.exec.common Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.nodes.exec.spec Class Description ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.reuse Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.plan.schema Class Description CatalogTable Represents the unresolved metadata of a table in aCatalog
.ContextResolvedTable This class contains information about a table, itsResolvedSchema
, its options and its relationship with aCatalog
, if any. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.typeutils Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.planner.utils Class Description CatalogMaterializedTable.LogicalRefreshMode The logical refresh mode of materialized table.CatalogMaterializedTable.RefreshMode The physical refresh mode of materialized table.Column Representation of a column in aResolvedSchema
.IntervalFreshness TheIntervalFreshness
represents freshness definition ofCatalogMaterializedTable
.TableChange TableChange
represents the modification of the table.TableChange.ColumnPosition The position of the modified or added column.TableDistribution Defines whether the given table is distributed across buckets using a specified algorithm and given columns. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.procedures Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.runtime.functions Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.runtime.functions.aggregate Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.runtime.functions.scalar Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.runtime.functions.table Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.extraction Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.inference Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.inference.transforms Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.inference.utils Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.logical Class Description ObjectIdentifier Identifies an object in a catalog.UnresolvedIdentifier Identifier of an object, such as table, view, function or type in a catalog. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.types.utils Class Description DataTypeFactory Factory for creating fully resolved data types that can be used for planning.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.typeutils Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.utils Class Description IntervalFreshness TheIntervalFreshness
represents freshness definition ofCatalogMaterializedTable
.ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.utils.print Class Description ResolvedSchema Schema of a table or view consisting of columns, constraints, and watermark specifications. -
Classes in org.apache.flink.table.catalog used by org.apache.flink.table.workflow Class Description ObjectIdentifier Identifies an object in a catalog.