@InterfaceAudience.Private
public interface IHMSHandler
extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface, org.apache.hadoop.conf.Configurable
| Modifier and Type | Method and Description |
|---|---|
org.apache.hadoop.hive.metastore.api.Database |
get_database_core(String catName,
String name)
Equivalent to get_database, but does not write to audit logs, or fire pre-event listeners.
|
org.apache.hadoop.hive.metastore.api.Table |
get_table_core(String catName,
String dbname,
String name)
Equivalent of get_table, but does not log audits and fire pre-event listener.
|
List<MetaStoreEventListener> |
getListeners()
Get a list of all non-transactional listeners.
|
RawStore |
getMS()
Get a reference to the underlying RawStore.
|
int |
getThreadId()
Get the id of the thread of this handler.
|
List<TransactionalMetaStoreEventListener> |
getTransactionalListeners()
Get a list of all transactional listeners.
|
TxnStore |
getTxnHandler()
Get a reference to the underlying TxnStore.
|
Warehouse |
getWh()
Get a reference to Hive's warehouse object (the class that does all the physical operations).
|
void |
init() |
abort_txn, add_dynamic_partitions, add_index, add_partition_with_environment_context, add_partition, add_partitions_pspec, add_partitions_req, add_partitions, alter_database, alter_function, alter_index, alter_partition_with_environment_context, alter_partition, alter_partitions, alter_table_with_cascade, alter_table_with_environment_context, alter_table, append_partition_by_name_with_environment_context, append_partition_by_name, append_partition_with_environment_context, append_partition, cancel_delegation_token, check_lock, commit_txn, compact, create_database, create_function, create_role, create_table_with_environment_context, create_table, create_type, delete_partition_column_statistics, delete_table_column_statistics, drop_database, drop_function, drop_index_by_name, drop_partition_by_name_with_environment_context, drop_partition_by_name, drop_partition_with_environment_context, drop_partition, drop_partitions_req, drop_role, drop_table_with_environment_context, drop_table, drop_type, exchange_partition, fire_listener_event, get_aggr_stats_for, get_all_databases, get_all_tables, get_config_value, get_current_notificationEventId, get_database, get_databases, get_delegation_token, get_fields_with_environment_context, get_fields, get_function, get_functions, get_index_by_name, get_index_names, get_indexes, get_next_notification, get_open_txns_info, get_open_txns, get_part_specs_by_filter, get_partition_by_name, get_partition_column_statistics, get_partition_names_ps, get_partition_names, get_partition_with_auth, get_partition, get_partitions_by_expr, get_partitions_by_filter, get_partitions_by_names, get_partitions_ps_with_auth, get_partitions_ps, get_partitions_pspec, get_partitions_statistics_req, get_partitions_with_auth, get_partitions, get_principals_in_role, get_privilege_set, get_role_grants_for_principal, get_role_names, get_schema_with_environment_context, get_schema, get_table_column_statistics, get_table_names_by_filter, get_table_objects_by_name, get_table_statistics_req, get_table, get_tables, get_type_all, get_type, getMetaConf, grant_privileges, grant_revoke_privileges, grant_revoke_role, grant_role, heartbeat_txn_range, heartbeat, isPartitionMarkedForEvent, list_privileges, list_roles, lock, markPartitionForEvent, open_txns, partition_name_has_valid_characters, partition_name_to_spec, partition_name_to_vals, rename_partition, renew_delegation_token, revoke_privileges, revoke_role, set_aggr_stats_for, set_ugi, setMetaConf, show_compact, show_locks, unlock, update_partition_column_statistics, update_table_column_statisticsvoid init() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaExceptionint getThreadId()
RawStore getMS() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException - if the creation of a new RawStore object is necessary but fails.TxnStore getTxnHandler()
Warehouse getWh()
org.apache.hadoop.hive.metastore.api.Database get_database_core(String catName, String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
catName - catalog namename - database nameorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - If the database does not exist.org.apache.hadoop.hive.metastore.api.MetaException - If another error occurs.org.apache.hadoop.hive.metastore.api.Table get_table_core(String catName, String dbname, String name) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
catName - catalog namedbname - database namename - table nameorg.apache.hadoop.hive.metastore.api.NoSuchObjectException - If the table does not exist.org.apache.hadoop.hive.metastore.api.MetaException - If another error occurs.List<TransactionalMetaStoreEventListener> getTransactionalListeners()
List<MetaStoreEventListener> getListeners()
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.