Uses of Interface
org.apache.flink.table.catalog.CatalogTable
-
-
Uses of CatalogTable in org.apache.flink.table.api
Methods in org.apache.flink.table.api that return CatalogTable Modifier and Type Method Description CatalogTable
TableDescriptor. toCatalogTable()
Converts this descriptor into aCatalogTable
. -
Uses of CatalogTable in org.apache.flink.table.catalog
Classes in org.apache.flink.table.catalog that implement CatalogTable Modifier and Type Class Description class
AbstractCatalogTable
An abstract catalog table.class
CatalogTableImpl
Deprecated.Useof(Schema, String, List, Map)
or a custom implementation instead.class
ConnectorCatalogTable<T1,T2>
class
DefaultCatalogTable
Default implementation of aCatalogTable
.class
ExternalCatalogTable
HelperCatalogTable
for representing a table that is backed by some inline connector (i.e.class
ResolvedCatalogTable
A validatedCatalogTable
that is backed by the original metadata coming from theCatalog
but resolved by the framework.Methods in org.apache.flink.table.catalog that return CatalogTable Modifier and Type Method Description CatalogTable
CatalogTable.Builder. build()
CatalogTable
CatalogTable. copy(Map<String,String> options)
Returns a copy of thisCatalogTable
with given table optionsoptions
.CatalogTable
CatalogTableImpl. copy(Map<String,String> options)
Deprecated.CatalogTable
ConnectorCatalogTable. copy(Map<String,String> options)
CatalogTable
DefaultCatalogTable. copy(Map<String,String> options)
CatalogTable
ExternalCatalogTable. copy(Map<String,String> options)
static CatalogTable
CatalogPropertiesUtil. deserializeCatalogTable(Map<String,String> properties)
Deserializes the given map of string properties into an unresolvedCatalogTable
.static CatalogTable
CatalogPropertiesUtil. deserializeCatalogTable(Map<String,String> properties, String fallbackKey)
Deserializes the given map of string properties into an unresolvedCatalogTable
.static CatalogTable
CatalogTable. fromProperties(Map<String,String> properties)
Creates an instance ofCatalogTable
from a map of string properties that were previously created withResolvedCatalogTable.toProperties()
.CatalogTable
ResolvedCatalogTable. getOrigin()
static CatalogTable
CatalogTable. of(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options)
Deprecated.Use the buildernewBuilder()
instead.static CatalogTable
CatalogTable. of(Schema schema, String comment, List<String> partitionKeys, Map<String,String> options, Long snapshot)
Deprecated.Use the buildernewBuilder()
instead.Methods in org.apache.flink.table.catalog with parameters of type CatalogTable Modifier and Type Method Description ResolvedCatalogTable
CatalogManager. resolveCatalogTable(CatalogTable table)
Resolves aCatalogTable
to a validatedResolvedCatalogTable
.Constructors in org.apache.flink.table.catalog with parameters of type CatalogTable Constructor Description ResolvedCatalogTable(CatalogTable origin, ResolvedSchema resolvedSchema)
-
Uses of CatalogTable in org.apache.flink.table.factories
Methods in org.apache.flink.table.factories that return CatalogTable Modifier and Type Method Description CatalogTable
TableSinkFactoryContextImpl. getTable()
Deprecated.CatalogTable
TableSourceFactoryContextImpl. getTable()
Deprecated.Methods in org.apache.flink.table.factories with parameters of type CatalogTable Modifier and Type Method Description static <T> TableSink<T>
TableFactoryUtil. findAndCreateTableSink(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isStreamingMode, boolean isTemporary)
Creates aTableSink
from aCatalogTable
.static <T> TableSource<T>
TableFactoryUtil. findAndCreateTableSource(Catalog catalog, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, ReadableConfig configuration, boolean isTemporary)
Creates aTableSource
from aCatalogTable
.static boolean
TableFactoryUtil. isLegacyConnectorOptions(Catalog catalog, ReadableConfig configuration, boolean isStreamingMode, ObjectIdentifier objectIdentifier, CatalogTable catalogTable, boolean isTemporary)
Checks whether theCatalogTable
uses legacy connector sink options.Constructors in org.apache.flink.table.factories with parameters of type CatalogTable Constructor Description TableSinkFactoryContextImpl(ObjectIdentifier identifier, CatalogTable table, ReadableConfig config, boolean isBounded, boolean isTemporary)
Deprecated.TableSourceFactoryContextImpl(ObjectIdentifier identifier, CatalogTable table, ReadableConfig config, boolean isTemporary)
Deprecated. -
Uses of CatalogTable in org.apache.flink.table.legacy.factories
Methods in org.apache.flink.table.legacy.factories that return CatalogTable Modifier and Type Method Description CatalogTable
TableSinkFactory.Context. getTable()
CatalogTable
TableSourceFactory.Context. getTable()
Methods in org.apache.flink.table.legacy.factories with parameters of type CatalogTable Modifier and Type Method Description default TableSink<T>
TableSinkFactory. createTableSink(ObjectPath tablePath, CatalogTable table)
Deprecated.TableSinkFactory.Context
contains more information, and already contains table schema too.default TableSource<T>
TableSourceFactory. createTableSource(ObjectPath tablePath, CatalogTable table)
Deprecated.TableSourceFactory.Context
contains more information, and already contains table schema too. -
Uses of CatalogTable in org.apache.flink.table.legacy.operations.ddl
Methods in org.apache.flink.table.legacy.operations.ddl that return CatalogTable Modifier and Type Method Description CatalogTable
AlterTableOptionsOperation. getCatalogTable()
Deprecated.Constructors in org.apache.flink.table.legacy.operations.ddl with parameters of type CatalogTable Constructor Description AlterTableOptionsOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfNotExists)
Deprecated. -
Uses of CatalogTable in org.apache.flink.table.operations.ddl
Methods in org.apache.flink.table.operations.ddl that return CatalogTable Modifier and Type Method Description CatalogTable
AlterTableSchemaOperation. getCatalogTable()
CatalogTable
CreateTableOperation. getCatalogTable()
CatalogTable
AlterTableChangeOperation. getNewTable()
Constructors in org.apache.flink.table.operations.ddl with parameters of type CatalogTable Constructor Description AlterTableChangeOperation(ObjectIdentifier tableIdentifier, List<TableChange> tableChanges, CatalogTable newTable, boolean ignoreIfNotExists)
AlterTableSchemaOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfNotExists)
CreateTableOperation(ObjectIdentifier tableIdentifier, CatalogTable catalogTable, boolean ignoreIfExists, boolean isTemporary)
-
Uses of CatalogTable in org.apache.flink.table.planner.plan.schema
Methods in org.apache.flink.table.planner.plan.schema that return CatalogTable Modifier and Type Method Description CatalogTable
CatalogSourceTable. getCatalogTable()
-