Modifier and Type | Method and Description |
---|---|
TableSink<Row> |
HiveTableFactory.createTableSink(ObjectPath tablePath,
CatalogTable table) |
TableSource<BaseRow> |
HiveTableFactory.createTableSource(ObjectPath tablePath,
CatalogTable table) |
Constructor and Description |
---|
HiveTableSink(org.apache.hadoop.mapred.JobConf jobConf,
ObjectPath tablePath,
CatalogTable table) |
HiveTableSource(org.apache.hadoop.mapred.JobConf jobConf,
ObjectPath tablePath,
CatalogTable catalogTable) |
Modifier and Type | Method and Description |
---|---|
static ObjectPath |
ObjectPath.fromString(String fullName) |
ObjectPath |
ObjectIdentifier.toObjectPath() |
Modifier and Type | Method and Description |
---|---|
void |
GenericInMemoryCatalog.alterFunction(ObjectPath path,
CatalogFunction newFunction,
boolean ignoreIfNotExists) |
void |
Catalog.alterFunction(ObjectPath functionPath,
CatalogFunction newFunction,
boolean ignoreIfNotExists)
Modify an existing function.
|
void |
GenericInMemoryCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
Catalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists)
Alter a partition.
|
void |
GenericInMemoryCatalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
Catalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists)
Update the column statistics of a table partition.
|
void |
GenericInMemoryCatalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists) |
void |
Catalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists)
Update the statistics of a table partition.
|
void |
GenericInMemoryCatalog.alterTable(ObjectPath tablePath,
CatalogBaseTable newTable,
boolean ignoreIfNotExists) |
void |
Catalog.alterTable(ObjectPath tablePath,
CatalogBaseTable newTable,
boolean ignoreIfNotExists)
Modify an existing table or view.
|
void |
GenericInMemoryCatalog.alterTableColumnStatistics(ObjectPath tablePath,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
Catalog.alterTableColumnStatistics(ObjectPath tablePath,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists)
Update the column statistics of a table.
|
void |
GenericInMemoryCatalog.alterTableStatistics(ObjectPath tablePath,
CatalogTableStatistics tableStatistics,
boolean ignoreIfNotExists) |
void |
Catalog.alterTableStatistics(ObjectPath tablePath,
CatalogTableStatistics tableStatistics,
boolean ignoreIfNotExists)
Update the statistics of a table.
|
void |
GenericInMemoryCatalog.createFunction(ObjectPath path,
CatalogFunction function,
boolean ignoreIfExists) |
void |
Catalog.createFunction(ObjectPath functionPath,
CatalogFunction function,
boolean ignoreIfExists)
Create a function.
|
void |
GenericInMemoryCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
Catalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists)
Create a partition.
|
void |
GenericInMemoryCatalog.createTable(ObjectPath tablePath,
CatalogBaseTable table,
boolean ignoreIfExists) |
void |
Catalog.createTable(ObjectPath tablePath,
CatalogBaseTable table,
boolean ignoreIfExists)
Create a new table or view.
|
void |
GenericInMemoryCatalog.dropFunction(ObjectPath path,
boolean ignoreIfNotExists) |
void |
Catalog.dropFunction(ObjectPath functionPath,
boolean ignoreIfNotExists)
Drop a function.
|
void |
GenericInMemoryCatalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
void |
Catalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists)
Drop a partition.
|
void |
GenericInMemoryCatalog.dropTable(ObjectPath tablePath,
boolean ignoreIfNotExists) |
void |
Catalog.dropTable(ObjectPath tablePath,
boolean ignoreIfNotExists)
Drop a table or view.
|
boolean |
GenericInMemoryCatalog.functionExists(ObjectPath path) |
boolean |
Catalog.functionExists(ObjectPath functionPath)
Check whether a function exists or not.
|
CatalogFunction |
GenericInMemoryCatalog.getFunction(ObjectPath path) |
CatalogFunction |
Catalog.getFunction(ObjectPath functionPath)
Get the function.
|
CatalogPartition |
GenericInMemoryCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogPartition |
Catalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get a partition of the given table.
|
CatalogColumnStatistics |
GenericInMemoryCatalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogColumnStatistics |
Catalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get the column statistics of a partition.
|
CatalogTableStatistics |
GenericInMemoryCatalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogTableStatistics |
Catalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get the statistics of a partition.
|
CatalogBaseTable |
GenericInMemoryCatalog.getTable(ObjectPath tablePath) |
CatalogBaseTable |
Catalog.getTable(ObjectPath tablePath)
Get a CatalogTable or CatalogView identified by tablePath.
|
CatalogColumnStatistics |
GenericInMemoryCatalog.getTableColumnStatistics(ObjectPath tablePath) |
CatalogColumnStatistics |
Catalog.getTableColumnStatistics(ObjectPath tablePath)
Get the column statistics of a table.
|
CatalogTableStatistics |
GenericInMemoryCatalog.getTableStatistics(ObjectPath tablePath) |
CatalogTableStatistics |
Catalog.getTableStatistics(ObjectPath tablePath)
Get the statistics of a table.
|
List<CatalogPartitionSpec> |
GenericInMemoryCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
Catalog.listPartitions(ObjectPath tablePath)
Get CatalogPartitionSpec of all partitions of the table.
|
List<CatalogPartitionSpec> |
GenericInMemoryCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
Catalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get CatalogPartitionSpec of all partitions that is under the given CatalogPartitionSpec in the table.
|
List<CatalogPartitionSpec> |
GenericInMemoryCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters) |
List<CatalogPartitionSpec> |
Catalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters)
Get CatalogPartitionSpec of partitions by expression filters in the table.
|
boolean |
GenericInMemoryCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
boolean |
Catalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Check whether a partition exists or not.
|
void |
GenericInMemoryCatalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists) |
void |
Catalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists)
Rename an existing table or view.
|
boolean |
GenericInMemoryCatalog.tableExists(ObjectPath tablePath) |
boolean |
Catalog.tableExists(ObjectPath tablePath)
Check if a table or view exists in this catalog.
|
Modifier and Type | Method and Description |
---|---|
void |
HiveCatalog.alterFunction(ObjectPath functionPath,
CatalogFunction newFunction,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterTable(ObjectPath tablePath,
CatalogBaseTable newCatalogTable,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterTableColumnStatistics(ObjectPath tablePath,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
HiveCatalog.alterTableStatistics(ObjectPath tablePath,
CatalogTableStatistics tableStatistics,
boolean ignoreIfNotExists) |
void |
HiveCatalog.createFunction(ObjectPath functionPath,
CatalogFunction function,
boolean ignoreIfExists) |
void |
HiveCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
HiveCatalog.createTable(ObjectPath tablePath,
CatalogBaseTable table,
boolean ignoreIfExists) |
void |
HiveCatalog.dropFunction(ObjectPath functionPath,
boolean ignoreIfNotExists) |
void |
HiveCatalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
void |
HiveCatalog.dropTable(ObjectPath tablePath,
boolean ignoreIfNotExists) |
boolean |
HiveCatalog.functionExists(ObjectPath functionPath) |
CatalogFunction |
HiveCatalog.getFunction(ObjectPath functionPath) |
org.apache.hadoop.hive.metastore.api.Table |
HiveCatalog.getHiveTable(ObjectPath tablePath) |
CatalogPartition |
HiveCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogColumnStatistics |
HiveCatalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogTableStatistics |
HiveCatalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogBaseTable |
HiveCatalog.getTable(ObjectPath tablePath) |
CatalogColumnStatistics |
HiveCatalog.getTableColumnStatistics(ObjectPath tablePath) |
CatalogTableStatistics |
HiveCatalog.getTableStatistics(ObjectPath tablePath) |
protected static org.apache.hadoop.hive.metastore.api.Table |
HiveCatalog.instantiateHiveTable(ObjectPath tablePath,
CatalogBaseTable table) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> expressions) |
boolean |
HiveCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
void |
HiveCatalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists) |
boolean |
HiveCatalog.tableExists(ObjectPath tablePath) |
Modifier and Type | Method and Description |
---|---|
default TableSink<T> |
TableSinkFactory.createTableSink(ObjectPath tablePath,
CatalogTable table)
Creates and configures a
TableSink based on the given CatalogTable instance. |
static Optional<TableSink> |
TableFactoryUtil.createTableSinkForCatalogTable(Catalog catalog,
CatalogTable catalogTable,
ObjectPath tablePath)
Creates a table sink for a
CatalogTable using table factory associated with the catalog. |
default TableSource<T> |
TableSourceFactory.createTableSource(ObjectPath tablePath,
CatalogTable table)
Creates and configures a
TableSource based on the given CatalogTable instance. |
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.