Modifier and Type | Field and Description |
---|---|
protected CatalogTable |
HiveTableSource.catalogTable |
Constructor and Description |
---|
HiveLookupTableSource(org.apache.hadoop.mapred.JobConf jobConf,
ReadableConfig flinkConf,
ObjectPath tablePath,
CatalogTable catalogTable) |
HiveSourceBuilder(org.apache.hadoop.mapred.JobConf jobConf,
ReadableConfig flinkConf,
ObjectPath tablePath,
String hiveVersion,
CatalogTable catalogTable)
Creates a builder to read a hive table.
|
HiveTableSink(ReadableConfig flinkConf,
org.apache.hadoop.mapred.JobConf jobConf,
ObjectIdentifier identifier,
CatalogTable table,
Integer configuredParallelism) |
HiveTableSource(org.apache.hadoop.mapred.JobConf jobConf,
ReadableConfig flinkConf,
ObjectPath tablePath,
CatalogTable catalogTable) |
Constructor and Description |
---|
HiveCompactReaderFactory(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
Properties properties,
org.apache.hadoop.mapred.JobConf jobConf,
CatalogTable catalogTable,
String hiveVersion,
RowType producedRowType,
boolean useMapRedReader) |
Modifier and Type | Method and Description |
---|---|
CatalogTable |
TableDescriptor.toCatalogTable()
Converts this descriptor into a
CatalogTable . |
Modifier and Type | Class and Description |
---|---|
class |
AbstractCatalogTable
An abstract catalog table.
|
class |
CatalogTableImpl
Deprecated.
Use
of(Schema, String, List, Map) or a custom implementation
instead. Don't implement against this internal class. It can lead to unintended side effects
if code checks against this class instead of the common interface. |
class |
ConnectorCatalogTable<T1,T2>
|
class |
DefaultCatalogTable
Default implementation of a
CatalogTable . |
class |
ExternalCatalogTable
Helper
CatalogTable for representing a table that is backed by some inline connector
(i.e. |
class |
ResolvedCatalogTable
A validated
CatalogTable that is backed by the original metadata coming from the Catalog but resolved by the framework. |
Modifier and Type | Method and Description |
---|---|
CatalogTable |
ExternalCatalogTable.copy(Map<String,String> options) |
CatalogTable |
ConnectorCatalogTable.copy(Map<String,String> options) |
CatalogTable |
CatalogTableImpl.copy(Map<String,String> options)
Deprecated.
|
CatalogTable |
CatalogTable.copy(Map<String,String> options)
Returns a copy of this
CatalogTable with given table options options . |
CatalogTable |
DefaultCatalogTable.copy(Map<String,String> options) |
static CatalogTable |
CatalogPropertiesUtil.deserializeCatalogTable(Map<String,String> properties)
Deserializes the given map of string properties into an unresolved
CatalogTable . |
static CatalogTable |
CatalogTable.fromProperties(Map<String,String> properties)
Creates an instance of
CatalogTable from a map of string properties that were
previously created with ResolvedCatalogTable.toProperties() . |
CatalogTable |
ResolvedCatalogTable.getOrigin() |
static CatalogTable |
CatalogTable.of(Schema schema,
String comment,
List<String> partitionKeys,
Map<String,String> options)
Creates a basic implementation of this interface.
|
Modifier and Type | Method and Description |
---|---|
ResolvedCatalogTable |
CatalogManager.resolveCatalogTable(CatalogTable table)
Resolves a
CatalogTable to a validated ResolvedCatalogTable . |
Constructor and Description |
---|
ResolvedCatalogTable(CatalogTable origin,
ResolvedSchema resolvedSchema) |
Modifier and Type | Method and Description |
---|---|
static void |
HiveTableUtil.alterColumns(org.apache.hadoop.hive.metastore.api.StorageDescriptor sd,
CatalogTable catalogTable) |
Modifier and Type | Method and Description |
---|---|
CatalogTable |
TableSourceFactoryContextImpl.getTable()
Deprecated.
|
CatalogTable |
TableSourceFactory.Context.getTable() |
CatalogTable |
TableSinkFactory.Context.getTable() |
CatalogTable |
TableSinkFactoryContextImpl.getTable()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
default TableSink<T> |
TableSinkFactory.createTableSink(ObjectPath tablePath,
CatalogTable table)
Deprecated.
TableSinkFactory.Context contains more information, and already contains table schema too.
Please use TableSinkFactory.createTableSink(Context) instead. |
default TableSource<T> |
TableSourceFactory.createTableSource(ObjectPath tablePath,
CatalogTable table)
Deprecated.
TableSourceFactory.Context contains more information, and already contains table schema too.
Please use TableSourceFactory.createTableSource(Context) instead. |
static <T> TableSink<T> |
TableFactoryUtil.findAndCreateTableSink(Catalog catalog,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
ReadableConfig configuration,
boolean isStreamingMode,
boolean isTemporary)
Creates a
TableSink from a CatalogTable . |
static <T> TableSource<T> |
TableFactoryUtil.findAndCreateTableSource(Catalog catalog,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
ReadableConfig configuration,
boolean isTemporary)
Creates a
TableSource from a CatalogTable . |
static boolean |
TableFactoryUtil.isLegacyConnectorOptions(Catalog catalog,
ReadableConfig configuration,
boolean isStreamingMode,
ObjectIdentifier objectIdentifier,
CatalogTable catalogTable,
boolean isTemporary)
Checks whether the
CatalogTable uses legacy connector sink options. |
Constructor and Description |
---|
TableSinkFactoryContextImpl(ObjectIdentifier identifier,
CatalogTable table,
ReadableConfig config,
boolean isBounded,
boolean isTemporary)
Deprecated.
|
TableSourceFactoryContextImpl(ObjectIdentifier identifier,
CatalogTable table,
ReadableConfig config,
boolean isTemporary)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
CatalogTable |
AlterTableSchemaOperation.getCatalogTable() |
CatalogTable |
AlterTableOptionsOperation.getCatalogTable() |
CatalogTable |
CreateTableOperation.getCatalogTable() |
Constructor and Description |
---|
AlterTableOptionsOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable) |
AlterTableSchemaOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable) |
CreateTableOperation(ObjectIdentifier tableIdentifier,
CatalogTable catalogTable,
boolean ignoreIfExists,
boolean isTemporary) |
Modifier and Type | Method and Description |
---|---|
CatalogTable |
CatalogSourceTable.getCatalogTable() |
Modifier and Type | Method and Description |
---|---|
static Operation |
OperationConverterUtils.convertAddReplaceColumns(ObjectIdentifier tableIdentifier,
SqlAddReplaceColumns addReplaceColumns,
CatalogTable catalogTable,
org.apache.calcite.sql.validate.SqlValidator sqlValidator) |
static Operation |
OperationConverterUtils.convertChangeColumn(ObjectIdentifier tableIdentifier,
SqlChangeColumn changeColumn,
CatalogTable catalogTable,
org.apache.calcite.sql.validate.SqlValidator sqlValidator) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.