Modifier and Type | Method and Description |
---|---|
static CatalogPartitionSpec |
HivePartitionUtils.createPartitionSpec(String hivePartitionName,
String defaultPartitionName)
Creates a
CatalogPartitionSpec from a Hive partition name string. |
Modifier and Type | Method and Description |
---|---|
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.
|
Modifier and Type | Method and Description |
---|---|
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.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.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
void |
Catalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists)
Drop a partition.
|
Optional<CatalogPartition> |
CatalogRegistry.getPartition(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec)
Retrieves a partition with a fully qualified table path and partition spec.
|
Optional<CatalogPartition> |
CatalogManager.getPartition(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec)
Retrieves a partition with a fully qualified table path and partition spec.
|
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.
|
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.
|
Map<String,String> |
ManagedTableListener.notifyTableCompaction(Catalog catalog,
ObjectIdentifier identifier,
ResolvedCatalogBaseTable<?> table,
CatalogPartitionSpec partitionSpec,
boolean isTemporary)
Deprecated.
Notify compaction for managed table.
|
boolean |
GenericInMemoryCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
boolean |
Catalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Check whether a partition exists or not.
|
Map<String,String> |
CatalogManager.resolveCompactManagedTableOptions(ResolvedCatalogTable origin,
ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec)
Resolve dynamic options for compact operation on a Flink's managed table.
|
Modifier and Type | Method and Description |
---|---|
default List<CatalogColumnStatistics> |
Catalog.bulkGetPartitionColumnStatistics(ObjectPath tablePath,
List<CatalogPartitionSpec> partitionSpecs)
Get a list of column statistics for given partitions.
|
default List<CatalogTableStatistics> |
Catalog.bulkGetPartitionStatistics(ObjectPath tablePath,
List<CatalogPartitionSpec> partitionSpecs)
Get a list of statistics of given partitions.
|
Constructor and Description |
---|
PartitionAlreadyExistsException(String catalogName,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
PartitionAlreadyExistsException(String catalogName,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
Throwable cause) |
PartitionNotExistException(String catalogName,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
PartitionNotExistException(String catalogName,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
Throwable cause) |
PartitionSpecInvalidException(String catalogName,
List<String> partitionKeys,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
PartitionSpecInvalidException(String catalogName,
List<String> partitionKeys,
ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> expressions) |
Modifier and Type | Method and Description |
---|---|
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.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
HiveCatalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
org.apache.hadoop.hive.metastore.api.Partition |
HiveCatalog.getHivePartition(org.apache.hadoop.hive.metastore.api.Table hiveTable,
CatalogPartitionSpec partitionSpec) |
CatalogPartition |
HiveCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogColumnStatistics |
HiveCatalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogTableStatistics |
HiveCatalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
boolean |
HiveCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
Modifier and Type | Method and Description |
---|---|
List<CatalogColumnStatistics> |
HiveCatalog.bulkGetPartitionColumnStatistics(ObjectPath tablePath,
List<CatalogPartitionSpec> partitionSpecs) |
List<CatalogTableStatistics> |
HiveCatalog.bulkGetPartitionStatistics(ObjectPath tablePath,
List<CatalogPartitionSpec> partitionSpecs) |
Modifier and Type | Method and Description |
---|---|
Map<String,String> |
ManagedTableFactory.onCompactTable(DynamicTableFactory.Context context,
CatalogPartitionSpec partitionSpec)
Deprecated.
Notifies the listener that a table compaction occurred.
|
Modifier and Type | Method and Description |
---|---|
List<CatalogPartitionSpec> |
TestFileSystemCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
TestFileSystemCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
TestFileSystemCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters) |
Modifier and Type | Method and Description |
---|---|
void |
TestFileSystemCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
TestFileSystemCatalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
TestFileSystemCatalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists) |
void |
TestFileSystemCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
TestFileSystemCatalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
CatalogPartition |
TestFileSystemCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogColumnStatistics |
TestFileSystemCatalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogTableStatistics |
TestFileSystemCatalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
TestFileSystemCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
boolean |
TestFileSystemCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
Modifier and Type | Method and Description |
---|---|
CatalogPartitionSpec |
ShowPartitionsOperation.getPartitionSpec() |
Modifier and Type | Method and Description |
---|---|
static String |
OperationUtils.formatPartitionSpec(CatalogPartitionSpec spec) |
Constructor and Description |
---|
ShowPartitionsOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec) |
ShowPartitionsOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec,
String defaultPartitionName) |
Modifier and Type | Field and Description |
---|---|
protected CatalogPartitionSpec |
AlterPartitionOperation.partitionSpec |
Modifier and Type | Method and Description |
---|---|
CatalogPartitionSpec |
AlterPartitionOperation.getPartitionSpec() |
Modifier and Type | Method and Description |
---|---|
Optional<List<CatalogPartitionSpec>> |
AnalyzeTableOperation.getPartitionSpecs()
Returns Optional.empty() if the table is not a partition table, else returns the given
partition specs.
|
List<CatalogPartitionSpec> |
AddPartitionsOperation.getPartitionSpecs() |
List<CatalogPartitionSpec> |
DropPartitionsOperation.getPartitionSpecs() |
Constructor and Description |
---|
AlterPartitionOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec) |
AlterPartitionPropertiesOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec,
CatalogPartition catalogPartition) |
Constructor and Description |
---|
AddPartitionsOperation(ObjectIdentifier tableIdentifier,
boolean ignoreIfPartitionExists,
List<CatalogPartitionSpec> partitionSpecs,
List<CatalogPartition> catalogPartitions) |
AnalyzeTableOperation(ObjectIdentifier tableIdentifier,
List<CatalogPartitionSpec> partitionSpecs,
List<Column> columns) |
DropPartitionsOperation(ObjectIdentifier tableIdentifier,
boolean ignoreIfPartitionNotExists,
List<CatalogPartitionSpec> partitionSpecs) |
Modifier and Type | Method and Description |
---|---|
CatalogPartitionSpec |
HiveParserQBMetaData.getDestPartitionForAlias(String alias) |
Modifier and Type | Method and Description |
---|---|
Map<String,Tuple3<String,CatalogTable,CatalogPartitionSpec>> |
HiveParserQBMetaData.getNameToDestPartition() |
Modifier and Type | Method and Description |
---|---|
void |
HiveParserQBMetaData.setDestForAlias(String alias,
String tabName,
CatalogTable tab,
CatalogPartitionSpec part) |
Modifier and Type | Field and Description |
---|---|
CatalogPartitionSpec |
HiveParserBaseSemanticAnalyzer.TableSpec.partHandle |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.