Package | Description |
---|---|
org.apache.flink.connector.jdbc.catalog | |
org.apache.flink.table.catalog | |
org.apache.flink.table.catalog.hive |
Modifier and Type | Method and Description |
---|---|
void |
AbstractJdbcCatalog.alterDatabase(String name,
CatalogDatabase newDatabase,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterFunction(ObjectPath functionPath,
CatalogFunction newFunction,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition newPartition,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterTable(ObjectPath tablePath,
CatalogBaseTable newTable,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterTableColumnStatistics(ObjectPath tablePath,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.alterTableStatistics(ObjectPath tablePath,
CatalogTableStatistics tableStatistics,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.close() |
void |
AbstractJdbcCatalog.createDatabase(String name,
CatalogDatabase database,
boolean ignoreIfExists) |
void |
AbstractJdbcCatalog.createFunction(ObjectPath functionPath,
CatalogFunction function,
boolean ignoreIfExists) |
void |
AbstractJdbcCatalog.createPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogPartition partition,
boolean ignoreIfExists) |
void |
AbstractJdbcCatalog.createTable(ObjectPath tablePath,
CatalogBaseTable table,
boolean ignoreIfExists) |
boolean |
AbstractJdbcCatalog.databaseExists(String databaseName) |
void |
AbstractJdbcCatalog.dropDatabase(String name,
boolean ignoreIfNotExists,
boolean cascade) |
void |
AbstractJdbcCatalog.dropFunction(ObjectPath functionPath,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.dropPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
boolean ignoreIfNotExists) |
void |
AbstractJdbcCatalog.dropTable(ObjectPath tablePath,
boolean ignoreIfNotExists) |
boolean |
AbstractJdbcCatalog.functionExists(ObjectPath functionPath) |
CatalogDatabase |
JdbcCatalog.getDatabase(String databaseName) |
CatalogDatabase |
AbstractJdbcCatalog.getDatabase(String databaseName) |
CatalogFunction |
AbstractJdbcCatalog.getFunction(ObjectPath functionPath) |
CatalogPartition |
AbstractJdbcCatalog.getPartition(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogColumnStatistics |
AbstractJdbcCatalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogTableStatistics |
AbstractJdbcCatalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
CatalogBaseTable |
JdbcCatalog.getTable(ObjectPath tablePath) |
CatalogBaseTable |
AbstractJdbcCatalog.getTable(ObjectPath tablePath) |
CatalogColumnStatistics |
AbstractJdbcCatalog.getTableColumnStatistics(ObjectPath tablePath) |
CatalogTableStatistics |
AbstractJdbcCatalog.getTableStatistics(ObjectPath tablePath) |
List<String> |
JdbcCatalog.listDatabases() |
List<String> |
MySqlCatalog.listDatabases() |
List<String> |
PostgresCatalog.listDatabases() |
List<String> |
AbstractJdbcCatalog.listFunctions(String dbName) |
List<CatalogPartitionSpec> |
AbstractJdbcCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
AbstractJdbcCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
AbstractJdbcCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> filters) |
List<String> |
JdbcCatalog.listTables(String databaseName) |
List<String> |
MySqlCatalog.listTables(String databaseName) |
List<String> |
PostgresCatalog.listTables(String databaseName) |
List<String> |
AbstractJdbcCatalog.listViews(String databaseName) |
void |
AbstractJdbcCatalog.open() |
boolean |
AbstractJdbcCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
void |
AbstractJdbcCatalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists) |
boolean |
JdbcCatalog.tableExists(ObjectPath tablePath) |
boolean |
MySqlCatalog.tableExists(ObjectPath tablePath) |
boolean |
PostgresCatalog.tableExists(ObjectPath tablePath) |
Modifier and Type | Method and Description |
---|---|
void |
Catalog.alterDatabase(String name,
CatalogDatabase newDatabase,
boolean ignoreIfNotExists)
Modify an existing database.
|
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 |
Catalog.alterPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists)
Update the column statistics of a table partition.
|
void |
Catalog.alterPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec,
CatalogTableStatistics partitionStatistics,
boolean ignoreIfNotExists)
Update the statistics of a table partition.
|
void |
Catalog.alterTable(ObjectPath tablePath,
CatalogBaseTable newTable,
boolean ignoreIfNotExists)
Modifies an existing table or view.
|
void |
Catalog.alterTableColumnStatistics(ObjectPath tablePath,
CatalogColumnStatistics columnStatistics,
boolean ignoreIfNotExists)
Update the column statistics of a table.
|
void |
Catalog.alterTableStatistics(ObjectPath tablePath,
CatalogTableStatistics tableStatistics,
boolean ignoreIfNotExists)
Update the statistics of a table.
|
void |
Catalog.close()
Close the catalog when it is no longer needed and release any resource that it might be
holding.
|
void |
Catalog.createDatabase(String name,
CatalogDatabase database,
boolean ignoreIfExists)
Create a database.
|
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 |
Catalog.createTable(ObjectPath tablePath,
CatalogBaseTable table,
boolean ignoreIfExists)
Creates a new table or view.
|
boolean |
Catalog.databaseExists(String databaseName)
Check if a database exists in this catalog.
|
default void |
Catalog.dropDatabase(String name,
boolean ignoreIfNotExists)
Drop a database.
|
void |
Catalog.dropDatabase(String name,
boolean ignoreIfNotExists,
boolean cascade)
Drop a database.
|
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 |
Catalog.dropTable(ObjectPath tablePath,
boolean ignoreIfNotExists)
Drop a table or view.
|
boolean |
Catalog.functionExists(ObjectPath functionPath)
Check whether a function exists or not.
|
CatalogDatabase |
Catalog.getDatabase(String databaseName)
Get a database from this catalog.
|
String |
Catalog.getDefaultDatabase()
Get the name of the default database for this catalog.
|
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 |
Catalog.getPartitionColumnStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get the column statistics of a partition.
|
CatalogTableStatistics |
Catalog.getPartitionStatistics(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Get the statistics of a partition.
|
CatalogBaseTable |
Catalog.getTable(ObjectPath tablePath)
|
CatalogColumnStatistics |
Catalog.getTableColumnStatistics(ObjectPath tablePath)
Get the column statistics of a table.
|
CatalogTableStatistics |
Catalog.getTableStatistics(ObjectPath tablePath)
Get the statistics of a table.
|
List<String> |
Catalog.listDatabases()
Get the names of all databases in this catalog.
|
List<String> |
Catalog.listFunctions(String dbName)
List the names of all functions in the given database.
|
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.
|
List<String> |
Catalog.listTables(String databaseName)
Get names of all tables and views under this database.
|
List<String> |
Catalog.listViews(String databaseName)
Get names of all views under this database.
|
CatalogFunction |
TemporaryOperationListener.onCreateTemporaryFunction(ObjectPath functionPath,
CatalogFunction function)
This method is called when a temporary function is to be created in this catalog.
|
CatalogBaseTable |
TemporaryOperationListener.onCreateTemporaryTable(ObjectPath tablePath,
CatalogBaseTable table)
This method is called when a temporary table or view is to be created in this catalog.
|
void |
TemporaryOperationListener.onDropTemporaryFunction(ObjectPath functionPath)
This method is called when a temporary function in this catalog is to be dropped.
|
void |
TemporaryOperationListener.onDropTemporaryTable(ObjectPath tablePath)
This method is called when a temporary table or view in this catalog is to be dropped.
|
void |
Catalog.open()
Open the catalog.
|
boolean |
GenericInMemoryCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
boolean |
Catalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec)
Check whether a partition exists or not.
|
void |
Catalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists)
Rename an existing table or view.
|
boolean |
Catalog.tableExists(ObjectPath tablePath)
Check if a table or view exists in this catalog.
|
Modifier and Type | Method and Description |
---|---|
void |
HiveCatalog.alterDatabase(String databaseName,
CatalogDatabase newDatabase,
boolean ignoreIfNotExists) |
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.close() |
void |
HiveCatalog.createDatabase(String databaseName,
CatalogDatabase database,
boolean ignoreIfExists) |
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) |
boolean |
HiveCatalog.databaseExists(String databaseName) |
void |
HiveCatalog.dropDatabase(String name,
boolean ignoreIfNotExists,
boolean cascade) |
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) |
CatalogDatabase |
HiveCatalog.getDatabase(String databaseName) |
CatalogFunction |
HiveCatalog.getFunction(ObjectPath functionPath) |
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) |
List<String> |
HiveCatalog.listDatabases() |
List<String> |
HiveCatalog.listFunctions(String databaseName) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitions(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
List<CatalogPartitionSpec> |
HiveCatalog.listPartitionsByFilter(ObjectPath tablePath,
List<Expression> expressions) |
List<String> |
HiveCatalog.listTables(String databaseName) |
List<String> |
HiveCatalog.listViews(String databaseName) |
void |
HiveCatalog.open() |
boolean |
HiveCatalog.partitionExists(ObjectPath tablePath,
CatalogPartitionSpec partitionSpec) |
void |
HiveCatalog.renameTable(ObjectPath tablePath,
String newTableName,
boolean ignoreIfNotExists) |
boolean |
HiveCatalog.tableExists(ObjectPath tablePath) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.