Package | Description |
---|---|
org.apache.flink.connector.jdbc.catalog | |
org.apache.flink.table.catalog | |
org.apache.flink.table.catalog.hive | |
org.apache.flink.table.operations.ddl |
Modifier and Type | Method and Description |
---|---|
CatalogPartition |
AbstractJdbcCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
Modifier and Type | Method and Description |
---|---|
void |
AbstractJdbcCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
Modifier and Type | Class and Description |
---|---|
class |
CatalogPartitionImpl
A catalog partition implementation.
|
Modifier and Type | Method and Description |
---|---|
CatalogPartition |
CatalogPartitionImpl.copy() |
CatalogPartition |
CatalogPartition.copy()
Get a deep copy of the CatalogPartition instance.
|
CatalogPartition |
GenericInMemoryCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogPartition |
Catalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get a partition of the given table.
|
Modifier and Type | Method and Description |
---|---|
Optional<CatalogPartition> |
CatalogManager.getPartition(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec)
Retrieves a partition with a fully qualified table path and partition spec.
|
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.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
Catalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists)
Create a partition.
|
Modifier and Type | Method and Description |
---|---|
CatalogPartition |
HiveCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
Modifier and Type | Method and Description |
---|---|
void |
HiveCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
HiveCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
Modifier and Type | Method and Description |
---|---|
CatalogPartition |
AlterPartitionPropertiesOperation.getCatalogPartition() |
Modifier and Type | Method and Description |
---|---|
List<CatalogPartition> |
AddPartitionsOperation.getCatalogPartitions() |
Constructor and Description |
---|
AlterPartitionPropertiesOperation(ObjectIdentifier tableIdentifier,
CatalogPartitionSpec partitionSpec,
CatalogPartition catalogPartition) |
Constructor and Description |
---|
AddPartitionsOperation(ObjectIdentifier tableIdentifier,
boolean ifNotExists,
List<CatalogPartitionSpec> partitionSpecs,
List<CatalogPartition> catalogPartitions) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.