public static class HiveMetaStore.HMSHandler extends com.facebook.fb303.FacebookBase implements IHMSHandler
Modifier and Type | Field and Description |
---|---|
static org.slf4j.Logger |
LOG |
Constructor and Description |
---|
HMSHandler(String name) |
HMSHandler(String name,
org.apache.hadoop.conf.Configuration conf) |
HMSHandler(String name,
org.apache.hadoop.conf.Configuration conf,
boolean init) |
Modifier and Type | Method and Description |
---|---|
void |
abort_txn(org.apache.hadoop.hive.metastore.api.AbortTxnRequest rqst) |
void |
abort_txns(org.apache.hadoop.hive.metastore.api.AbortTxnsRequest rqst) |
void |
add_check_constraint(org.apache.hadoop.hive.metastore.api.AddCheckConstraintRequest req) |
void |
add_default_constraint(org.apache.hadoop.hive.metastore.api.AddDefaultConstraintRequest req) |
void |
add_dynamic_partitions(org.apache.hadoop.hive.metastore.api.AddDynamicPartitions rqst) |
void |
add_foreign_key(org.apache.hadoop.hive.metastore.api.AddForeignKeyRequest req) |
int |
add_master_key(String key) |
void |
add_not_null_constraint(org.apache.hadoop.hive.metastore.api.AddNotNullConstraintRequest req) |
org.apache.hadoop.hive.metastore.api.Partition |
add_partition_with_environment_context(org.apache.hadoop.hive.metastore.api.Partition part,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
org.apache.hadoop.hive.metastore.api.Partition |
add_partition(org.apache.hadoop.hive.metastore.api.Partition part) |
int |
add_partitions_pspec(List<org.apache.hadoop.hive.metastore.api.PartitionSpec> partSpecs) |
org.apache.hadoop.hive.metastore.api.AddPartitionsResult |
add_partitions_req(org.apache.hadoop.hive.metastore.api.AddPartitionsRequest request) |
int |
add_partitions(List<org.apache.hadoop.hive.metastore.api.Partition> parts) |
void |
add_primary_key(org.apache.hadoop.hive.metastore.api.AddPrimaryKeyRequest req) |
void |
add_runtime_stats(org.apache.hadoop.hive.metastore.api.RuntimeStat stat) |
void |
add_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersion schemaVersion) |
void |
add_serde(org.apache.hadoop.hive.metastore.api.SerDeInfo serde) |
boolean |
add_token(String token_identifier,
String delegation_token) |
void |
add_unique_constraint(org.apache.hadoop.hive.metastore.api.AddUniqueConstraintRequest req) |
org.apache.hadoop.hive.metastore.api.AllocateTableWriteIdsResponse |
allocate_table_write_ids(org.apache.hadoop.hive.metastore.api.AllocateTableWriteIdsRequest rqst) |
void |
alter_catalog(org.apache.hadoop.hive.metastore.api.AlterCatalogRequest rqst) |
void |
alter_database(String dbName,
org.apache.hadoop.hive.metastore.api.Database newDB) |
void |
alter_function(String dbName,
String funcName,
org.apache.hadoop.hive.metastore.api.Function newFunc) |
void |
alter_ischema(org.apache.hadoop.hive.metastore.api.AlterISchemaRequest rqst) |
void |
alter_partition_with_environment_context(String dbName,
String tableName,
org.apache.hadoop.hive.metastore.api.Partition newPartition,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
void |
alter_partition(String db_name,
String tbl_name,
org.apache.hadoop.hive.metastore.api.Partition new_part) |
void |
alter_partitions_with_environment_context(String db_name,
String tbl_name,
List<org.apache.hadoop.hive.metastore.api.Partition> new_parts,
org.apache.hadoop.hive.metastore.api.EnvironmentContext environmentContext) |
void |
alter_partitions(String db_name,
String tbl_name,
List<org.apache.hadoop.hive.metastore.api.Partition> new_parts) |
org.apache.hadoop.hive.metastore.api.WMAlterResourcePlanResponse |
alter_resource_plan(org.apache.hadoop.hive.metastore.api.WMAlterResourcePlanRequest request) |
void |
alter_table_with_cascade(String dbname,
String name,
org.apache.hadoop.hive.metastore.api.Table newTable,
boolean cascade) |
void |
alter_table_with_environment_context(String dbname,
String name,
org.apache.hadoop.hive.metastore.api.Table newTable,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
void |
alter_table(String dbname,
String name,
org.apache.hadoop.hive.metastore.api.Table newTable) |
org.apache.hadoop.hive.metastore.api.WMAlterPoolResponse |
alter_wm_pool(org.apache.hadoop.hive.metastore.api.WMAlterPoolRequest request) |
org.apache.hadoop.hive.metastore.api.WMAlterTriggerResponse |
alter_wm_trigger(org.apache.hadoop.hive.metastore.api.WMAlterTriggerRequest request) |
org.apache.hadoop.hive.metastore.api.Partition |
append_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
org.apache.hadoop.hive.metastore.api.EnvironmentContext env_context) |
org.apache.hadoop.hive.metastore.api.Partition |
append_partition_by_name(String db_name,
String tbl_name,
String part_name) |
org.apache.hadoop.hive.metastore.api.Partition |
append_partition_with_environment_context(String dbName,
String tableName,
List<String> part_vals,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
org.apache.hadoop.hive.metastore.api.Partition |
append_partition(String dbName,
String tableName,
List<String> part_vals) |
org.apache.hadoop.hive.metastore.api.CacheFileMetadataResult |
cache_file_metadata(org.apache.hadoop.hive.metastore.api.CacheFileMetadataRequest req) |
void |
cancel_delegation_token(String token_str_form) |
org.apache.hadoop.hive.metastore.api.LockResponse |
check_lock(org.apache.hadoop.hive.metastore.api.CheckLockRequest rqst) |
org.apache.hadoop.hive.metastore.api.ClearFileMetadataResult |
clear_file_metadata(org.apache.hadoop.hive.metastore.api.ClearFileMetadataRequest req) |
org.apache.hadoop.hive.metastore.api.CmRecycleResponse |
cm_recycle(org.apache.hadoop.hive.metastore.api.CmRecycleRequest request) |
void |
commit_txn(org.apache.hadoop.hive.metastore.api.CommitTxnRequest rqst) |
void |
compact(org.apache.hadoop.hive.metastore.api.CompactionRequest rqst)
Deprecated.
|
org.apache.hadoop.hive.metastore.api.CompactionResponse |
compact2(org.apache.hadoop.hive.metastore.api.CompactionRequest rqst) |
void |
create_catalog(org.apache.hadoop.hive.metastore.api.CreateCatalogRequest rqst) |
void |
create_database(org.apache.hadoop.hive.metastore.api.Database db) |
void |
create_function(org.apache.hadoop.hive.metastore.api.Function func) |
void |
create_ischema(org.apache.hadoop.hive.metastore.api.ISchema schema) |
org.apache.hadoop.hive.metastore.api.WMCreateOrDropTriggerToPoolMappingResponse |
create_or_drop_wm_trigger_to_pool_mapping(org.apache.hadoop.hive.metastore.api.WMCreateOrDropTriggerToPoolMappingRequest request) |
org.apache.hadoop.hive.metastore.api.WMCreateOrUpdateMappingResponse |
create_or_update_wm_mapping(org.apache.hadoop.hive.metastore.api.WMCreateOrUpdateMappingRequest request) |
org.apache.hadoop.hive.metastore.api.WMCreateResourcePlanResponse |
create_resource_plan(org.apache.hadoop.hive.metastore.api.WMCreateResourcePlanRequest request) |
boolean |
create_role(org.apache.hadoop.hive.metastore.api.Role role) |
void |
create_table_with_constraints(org.apache.hadoop.hive.metastore.api.Table tbl,
List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> primaryKeys,
List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> foreignKeys,
List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uniqueConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> notNullConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> defaultConstraints,
List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> checkConstraints) |
void |
create_table_with_environment_context(org.apache.hadoop.hive.metastore.api.Table tbl,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
void |
create_table(org.apache.hadoop.hive.metastore.api.Table tbl) |
boolean |
create_type(org.apache.hadoop.hive.metastore.api.Type type) |
org.apache.hadoop.hive.metastore.api.WMCreatePoolResponse |
create_wm_pool(org.apache.hadoop.hive.metastore.api.WMCreatePoolRequest request) |
org.apache.hadoop.hive.metastore.api.WMCreateTriggerResponse |
create_wm_trigger(org.apache.hadoop.hive.metastore.api.WMCreateTriggerRequest request) |
static void |
createDefaultCatalog(RawStore ms,
Warehouse wh) |
boolean |
delete_partition_column_statistics(String dbName,
String tableName,
String partName,
String colName) |
boolean |
delete_table_column_statistics(String dbName,
String tableName,
String colName) |
void |
drop_catalog(org.apache.hadoop.hive.metastore.api.DropCatalogRequest rqst) |
void |
drop_constraint(org.apache.hadoop.hive.metastore.api.DropConstraintRequest req) |
void |
drop_database(String dbName,
boolean deleteData,
boolean cascade) |
void |
drop_function(String dbName,
String funcName) |
void |
drop_ischema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) |
boolean |
drop_partition_by_name_with_environment_context(String db_name,
String tbl_name,
String part_name,
boolean deleteData,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
boolean |
drop_partition_by_name(String db_name,
String tbl_name,
String part_name,
boolean deleteData) |
boolean |
drop_partition_with_environment_context(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
boolean |
drop_partition(String db_name,
String tbl_name,
List<String> part_vals,
boolean deleteData) |
org.apache.hadoop.hive.metastore.api.DropPartitionsResult |
drop_partitions_req(org.apache.hadoop.hive.metastore.api.DropPartitionsRequest request) |
org.apache.hadoop.hive.metastore.api.WMDropResourcePlanResponse |
drop_resource_plan(org.apache.hadoop.hive.metastore.api.WMDropResourcePlanRequest request) |
boolean |
drop_role(String roleName) |
void |
drop_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version) |
void |
drop_table_with_environment_context(String dbname,
String name,
boolean deleteData,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
void |
drop_table(String dbname,
String name,
boolean deleteData) |
boolean |
drop_type(String name) |
org.apache.hadoop.hive.metastore.api.WMDropMappingResponse |
drop_wm_mapping(org.apache.hadoop.hive.metastore.api.WMDropMappingRequest request) |
org.apache.hadoop.hive.metastore.api.WMDropPoolResponse |
drop_wm_pool(org.apache.hadoop.hive.metastore.api.WMDropPoolRequest request) |
org.apache.hadoop.hive.metastore.api.WMDropTriggerResponse |
drop_wm_trigger(org.apache.hadoop.hive.metastore.api.WMDropTriggerRequest request) |
org.apache.hadoop.hive.metastore.api.Partition |
exchange_partition(Map<String,String> partitionSpecs,
String sourceDbName,
String sourceTableName,
String destDbName,
String destTableName) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
exchange_partitions(Map<String,String> partitionSpecs,
String sourceDbName,
String sourceTableName,
String destDbName,
String destTableName) |
org.apache.hadoop.hive.metastore.api.FireEventResponse |
fire_listener_event(org.apache.hadoop.hive.metastore.api.FireEventRequest rqst) |
void |
flushCache() |
org.apache.hadoop.hive.metastore.api.WMGetActiveResourcePlanResponse |
get_active_resource_plan(org.apache.hadoop.hive.metastore.api.WMGetActiveResourcePlanRequest request) |
org.apache.hadoop.hive.metastore.api.AggrStats |
get_aggr_stats_for(org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest request) |
List<String> |
get_all_databases() |
org.apache.hadoop.hive.metastore.api.GetAllFunctionsResponse |
get_all_functions() |
org.apache.hadoop.hive.metastore.api.WMGetAllResourcePlanResponse |
get_all_resource_plans(org.apache.hadoop.hive.metastore.api.WMGetAllResourcePlanRequest request) |
List<String> |
get_all_tables(String dbname) |
List<String> |
get_all_token_identifiers() |
org.apache.hadoop.hive.metastore.api.GetCatalogResponse |
get_catalog(org.apache.hadoop.hive.metastore.api.GetCatalogRequest rqst) |
org.apache.hadoop.hive.metastore.api.GetCatalogsResponse |
get_catalogs() |
org.apache.hadoop.hive.metastore.api.CheckConstraintsResponse |
get_check_constraints(org.apache.hadoop.hive.metastore.api.CheckConstraintsRequest request) |
String |
get_config_value(String name,
String defaultValue)
Returns the value of the given configuration variable name.
|
org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId |
get_current_notificationEventId() |
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.Database |
get_database(String name) |
List<String> |
get_databases(String pattern) |
org.apache.hadoop.hive.metastore.api.DefaultConstraintsResponse |
get_default_constraints(org.apache.hadoop.hive.metastore.api.DefaultConstraintsRequest request) |
String |
get_delegation_token(String token_owner,
String renewer_kerberos_principal_name) |
List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
get_fields_with_environment_context(String db,
String tableName,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) |
List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
get_fields(String db,
String tableName) |
org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprResult |
get_file_metadata_by_expr(org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprRequest req) |
org.apache.hadoop.hive.metastore.api.GetFileMetadataResult |
get_file_metadata(org.apache.hadoop.hive.metastore.api.GetFileMetadataRequest req) |
org.apache.hadoop.hive.metastore.api.ForeignKeysResponse |
get_foreign_keys(org.apache.hadoop.hive.metastore.api.ForeignKeysRequest request) |
org.apache.hadoop.hive.metastore.api.Function |
get_function(String dbName,
String funcName) |
List<String> |
get_functions(String dbName,
String pattern) |
org.apache.hadoop.hive.metastore.api.ISchema |
get_ischema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) |
org.apache.hadoop.hive.metastore.api.LockResponse |
get_lock_materialization_rebuild(String dbName,
String tableName,
long txnId) |
List<String> |
get_master_keys() |
org.apache.hadoop.hive.metastore.api.Materialization |
get_materialization_invalidation_info(org.apache.hadoop.hive.metastore.api.CreationMetadata cm,
String validTxnList) |
List<String> |
get_materialized_views_for_rewriting(String dbname) |
String |
get_metastore_db_uuid() |
org.apache.hadoop.hive.metastore.api.NotificationEventResponse |
get_next_notification(org.apache.hadoop.hive.metastore.api.NotificationEventRequest rqst) |
org.apache.hadoop.hive.metastore.api.NotNullConstraintsResponse |
get_not_null_constraints(org.apache.hadoop.hive.metastore.api.NotNullConstraintsRequest request) |
org.apache.hadoop.hive.metastore.api.NotificationEventsCountResponse |
get_notification_events_count(org.apache.hadoop.hive.metastore.api.NotificationEventsCountRequest rqst) |
int |
get_num_partitions_by_filter(String dbName,
String tblName,
String filter) |
org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse |
get_open_txns_info() |
org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse |
get_open_txns() |
List<org.apache.hadoop.hive.metastore.api.PartitionSpec> |
get_part_specs_by_filter(String dbName,
String tblName,
String filter,
int maxParts) |
org.apache.hadoop.hive.metastore.api.Partition |
get_partition_by_name(String db_name,
String tbl_name,
String part_name) |
org.apache.hadoop.hive.metastore.api.ColumnStatistics |
get_partition_column_statistics(String dbName,
String tableName,
String partName,
String colName) |
List<String> |
get_partition_names_ps(String db_name,
String tbl_name,
List<String> part_vals,
short max_parts) |
List<String> |
get_partition_names(String db_name,
String tbl_name,
short max_parts) |
org.apache.hadoop.hive.metastore.api.PartitionValuesResponse |
get_partition_values(org.apache.hadoop.hive.metastore.api.PartitionValuesRequest request) |
org.apache.hadoop.hive.metastore.api.Partition |
get_partition_with_auth(String db_name,
String tbl_name,
List<String> part_vals,
String user_name,
List<String> group_names) |
org.apache.hadoop.hive.metastore.api.Partition |
get_partition(String db_name,
String tbl_name,
List<String> part_vals) |
org.apache.hadoop.hive.metastore.api.PartitionsByExprResult |
get_partitions_by_expr(org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest req) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions_by_filter(String dbName,
String tblName,
String filter,
short maxParts) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions_by_names(String dbName,
String tblName,
List<String> partNames) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions_ps_with_auth(String db_name,
String tbl_name,
List<String> part_vals,
short max_parts,
String userName,
List<String> groupNames) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions_ps(String db_name,
String tbl_name,
List<String> part_vals,
short max_parts) |
List<org.apache.hadoop.hive.metastore.api.PartitionSpec> |
get_partitions_pspec(String db_name,
String tbl_name,
int max_parts) |
org.apache.hadoop.hive.metastore.api.PartitionsStatsResult |
get_partitions_statistics_req(org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest request) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions_with_auth(String dbName,
String tblName,
short maxParts,
String userName,
List<String> groupNames) |
List<org.apache.hadoop.hive.metastore.api.Partition> |
get_partitions(String db_name,
String tbl_name,
short max_parts) |
org.apache.hadoop.hive.metastore.api.PrimaryKeysResponse |
get_primary_keys(org.apache.hadoop.hive.metastore.api.PrimaryKeysRequest request) |
org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse |
get_principals_in_role(org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest request) |
org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet |
get_privilege_set(org.apache.hadoop.hive.metastore.api.HiveObjectRef hiveObject,
String userName,
List<String> groupNames) |
org.apache.hadoop.hive.metastore.api.WMGetResourcePlanResponse |
get_resource_plan(org.apache.hadoop.hive.metastore.api.WMGetResourcePlanRequest request) |
org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse |
get_role_grants_for_principal(org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest request) |
List<String> |
get_role_names() |
List<org.apache.hadoop.hive.metastore.api.RuntimeStat> |
get_runtime_stats(org.apache.hadoop.hive.metastore.api.GetRuntimeStatsRequest rqst) |
List<org.apache.hadoop.hive.metastore.api.SchemaVersion> |
get_schema_all_versions(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) |
org.apache.hadoop.hive.metastore.api.SchemaVersion |
get_schema_latest_version(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) |
org.apache.hadoop.hive.metastore.api.SchemaVersion |
get_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version) |
List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
get_schema_with_environment_context(String db,
String tableName,
org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext)
Return the schema of the table.
|
List<org.apache.hadoop.hive.metastore.api.FieldSchema> |
get_schema(String db,
String tableName)
Return the schema of the table.
|
org.apache.hadoop.hive.metastore.api.FindSchemasByColsResp |
get_schemas_by_cols(org.apache.hadoop.hive.metastore.api.FindSchemasByColsRqst rqst) |
org.apache.hadoop.hive.metastore.api.SerDeInfo |
get_serde(org.apache.hadoop.hive.metastore.api.GetSerdeRequest rqst) |
org.apache.hadoop.hive.metastore.api.ColumnStatistics |
get_table_column_statistics(String dbName,
String tableName,
String colName) |
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<org.apache.hadoop.hive.metastore.api.TableMeta> |
get_table_meta(String dbnames,
String tblNames,
List<String> tblTypes) |
List<String> |
get_table_names_by_filter(String dbName,
String filter,
short maxTables) |
org.apache.hadoop.hive.metastore.api.GetTablesResult |
get_table_objects_by_name_req(org.apache.hadoop.hive.metastore.api.GetTablesRequest req) |
List<org.apache.hadoop.hive.metastore.api.Table> |
get_table_objects_by_name(String dbName,
List<String> tableNames)
Deprecated.
|
org.apache.hadoop.hive.metastore.api.GetTableResult |
get_table_req(org.apache.hadoop.hive.metastore.api.GetTableRequest req) |
org.apache.hadoop.hive.metastore.api.TableStatsResult |
get_table_statistics_req(org.apache.hadoop.hive.metastore.api.TableStatsRequest request) |
org.apache.hadoop.hive.metastore.api.Table |
get_table(String dbname,
String name)
Deprecated.
|
List<String> |
get_tables_by_type(String dbname,
String pattern,
String tableType) |
List<String> |
get_tables(String dbname,
String pattern) |
String |
get_token(String token_identifier) |
org.apache.hadoop.hive.metastore.api.WMGetTriggersForResourePlanResponse |
get_triggers_for_resourceplan(org.apache.hadoop.hive.metastore.api.WMGetTriggersForResourePlanRequest request) |
Map<String,org.apache.hadoop.hive.metastore.api.Type> |
get_type_all(String name) |
org.apache.hadoop.hive.metastore.api.Type |
get_type(String name) |
org.apache.hadoop.hive.metastore.api.UniqueConstraintsResponse |
get_unique_constraints(org.apache.hadoop.hive.metastore.api.UniqueConstraintsRequest request) |
org.apache.hadoop.hive.metastore.api.GetValidWriteIdsResponse |
get_valid_write_ids(org.apache.hadoop.hive.metastore.api.GetValidWriteIdsRequest rqst) |
static Integer |
get()
Deprecated.
|
org.apache.hadoop.conf.Configuration |
getConf() |
AbstractMap<String,Long> |
getCounters() |
String |
getCpuProfile(int profileDurationInSec) |
org.apache.hadoop.conf.Configuration |
getHiveConf()
Deprecated.
|
List<MetaStoreEventListener> |
getListeners()
Get a list of all non-transactional listeners.
|
String |
getMetaConf(String key) |
RawStore |
getMS()
Get a cached RawStore.
|
static RawStore |
getMSForConf(org.apache.hadoop.conf.Configuration conf) |
static RawStore |
getRawStore() |
com.facebook.fb303.fb_status |
getStatus() |
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.
|
String |
getVersion() |
Warehouse |
getWh()
Get a reference to Hive's warehouse object (the class that does all the physical operations).
|
boolean |
grant_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges) |
org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse |
grant_revoke_privileges(org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest request) |
org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse |
grant_revoke_role(org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest request) |
boolean |
grant_role(String roleName,
String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
String grantor,
org.apache.hadoop.hive.metastore.api.PrincipalType grantorType,
boolean grantOption) |
boolean |
heartbeat_lock_materialization_rebuild(String dbName,
String tableName,
long txnId) |
org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse |
heartbeat_txn_range(org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest rqst) |
void |
heartbeat(org.apache.hadoop.hive.metastore.api.HeartbeatRequest ids) |
void |
init() |
boolean |
isPartitionMarkedForEvent(String db_name,
String tbl_name,
Map<String,String> partName,
org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) |
List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> |
list_privileges(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType,
org.apache.hadoop.hive.metastore.api.HiveObjectRef hiveObject) |
List<org.apache.hadoop.hive.metastore.api.Role> |
list_roles(String principalName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType) |
org.apache.hadoop.hive.metastore.api.LockResponse |
lock(org.apache.hadoop.hive.metastore.api.LockRequest rqst) |
void |
map_schema_version_to_serde(org.apache.hadoop.hive.metastore.api.MapSchemaVersionToSerdeRequest rqst) |
void |
markPartitionForEvent(String db_name,
String tbl_name,
Map<String,String> partName,
org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) |
org.apache.hadoop.hive.metastore.api.OpenTxnsResponse |
open_txns(org.apache.hadoop.hive.metastore.api.OpenTxnRequest rqst) |
boolean |
partition_name_has_valid_characters(List<String> part_vals,
boolean throw_exception) |
Map<String,String> |
partition_name_to_spec(String part_name) |
List<String> |
partition_name_to_vals(String part_name) |
org.apache.hadoop.hive.metastore.api.PutFileMetadataResult |
put_file_metadata(org.apache.hadoop.hive.metastore.api.PutFileMetadataRequest req) |
org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse |
refresh_privileges(org.apache.hadoop.hive.metastore.api.HiveObjectRef objToRefresh,
String authorizer,
org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest grantRequest) |
boolean |
remove_master_key(int key_seq) |
boolean |
remove_token(String token_identifier) |
void |
rename_partition(String db_name,
String tbl_name,
List<String> part_vals,
org.apache.hadoop.hive.metastore.api.Partition new_part) |
long |
renew_delegation_token(String token_str_form) |
void |
repl_tbl_writeid_state(org.apache.hadoop.hive.metastore.api.ReplTblWriteIdStateRequest rqst) |
boolean |
revoke_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges) |
boolean |
revoke_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges,
boolean grantOption) |
boolean |
revoke_role(String roleName,
String userName,
org.apache.hadoop.hive.metastore.api.PrincipalType principalType) |
boolean |
set_aggr_stats_for(org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest request) |
void |
set_schema_version_state(org.apache.hadoop.hive.metastore.api.SetSchemaVersionStateRequest rqst) |
List<String> |
set_ugi(String username,
List<String> groupNames) |
void |
setConf(org.apache.hadoop.conf.Configuration conf) |
void |
setMetaConf(String key,
String value) |
org.apache.hadoop.hive.metastore.api.ShowCompactResponse |
show_compact(org.apache.hadoop.hive.metastore.api.ShowCompactRequest rqst) |
org.apache.hadoop.hive.metastore.api.ShowLocksResponse |
show_locks(org.apache.hadoop.hive.metastore.api.ShowLocksRequest rqst) |
void |
shutdown() |
void |
truncate_table(String dbName,
String tableName,
List<String> partNames) |
void |
unlock(org.apache.hadoop.hive.metastore.api.UnlockRequest rqst) |
void |
update_creation_metadata(String catName,
String dbName,
String tableName,
org.apache.hadoop.hive.metastore.api.CreationMetadata cm) |
void |
update_master_key(int seq_number,
String key) |
boolean |
update_partition_column_statistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats) |
boolean |
update_table_column_statistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats) |
org.apache.hadoop.hive.metastore.api.WMValidateResourcePlanResponse |
validate_resource_plan(org.apache.hadoop.hive.metastore.api.WMValidateResourcePlanRequest request) |
aliveSince, deleteCounter, getCounter, getCpuProfile, getName, getOption, getOptions, getStatusDetails, incrementCounter, incrementCounter, reinitialize, resetCounter, setCounter, setOption
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
public HMSHandler(String name) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public HMSHandler(String name, org.apache.hadoop.conf.Configuration conf) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public HMSHandler(String name, org.apache.hadoop.conf.Configuration conf, boolean init) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public static RawStore getRawStore()
@Deprecated public static Integer get()
getThreadId()
instead.public int getThreadId()
IHMSHandler
getThreadId
in interface IHMSHandler
@Deprecated public org.apache.hadoop.conf.Configuration getHiveConf()
getConf()
instead.public List<TransactionalMetaStoreEventListener> getTransactionalListeners()
IHMSHandler
getTransactionalListeners
in interface IHMSHandler
public List<MetaStoreEventListener> getListeners()
IHMSHandler
getListeners
in interface IHMSHandler
public void init() throws org.apache.hadoop.hive.metastore.api.MetaException
init
in interface IHMSHandler
org.apache.hadoop.hive.metastore.api.MetaException
public void setConf(org.apache.hadoop.conf.Configuration conf)
setConf
in interface org.apache.hadoop.conf.Configurable
public org.apache.hadoop.conf.Configuration getConf()
getConf
in interface org.apache.hadoop.conf.Configurable
public Warehouse getWh()
IHMSHandler
getWh
in interface IHMSHandler
public void setMetaConf(String key, String value) throws org.apache.hadoop.hive.metastore.api.MetaException
setMetaConf
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public String getMetaConf(String key) throws org.apache.hadoop.hive.metastore.api.MetaException
getMetaConf
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public RawStore getMS() throws org.apache.hadoop.hive.metastore.api.MetaException
getMS
in interface IHMSHandler
org.apache.hadoop.hive.metastore.api.MetaException
public static RawStore getMSForConf(org.apache.hadoop.conf.Configuration conf) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public TxnStore getTxnHandler()
IHMSHandler
getTxnHandler
in interface IHMSHandler
public static void createDefaultCatalog(RawStore ms, Warehouse wh) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
public com.facebook.fb303.fb_status getStatus()
getStatus
in interface com.facebook.fb303.FacebookService.Iface
getStatus
in class com.facebook.fb303.FacebookBase
public void shutdown()
shutdown
in interface com.facebook.fb303.FacebookService.Iface
shutdown
in class com.facebook.fb303.FacebookBase
public AbstractMap<String,Long> getCounters()
getCounters
in interface com.facebook.fb303.FacebookService.Iface
getCounters
in class com.facebook.fb303.FacebookBase
public void create_catalog(org.apache.hadoop.hive.metastore.api.CreateCatalogRequest rqst) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public void alter_catalog(org.apache.hadoop.hive.metastore.api.AlterCatalogRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetCatalogResponse get_catalog(org.apache.hadoop.hive.metastore.api.GetCatalogRequest rqst) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetCatalogsResponse get_catalogs() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public void drop_catalog(org.apache.hadoop.hive.metastore.api.DropCatalogRequest rqst) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
public void create_database(org.apache.hadoop.hive.metastore.api.Database db) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException
create_database
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.Database get_database(String name) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
get_database
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public 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
IHMSHandler
get_database_core
in interface IHMSHandler
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.public void alter_database(String dbName, org.apache.hadoop.hive.metastore.api.Database newDB) throws org.apache.thrift.TException
alter_database
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void drop_database(String dbName, boolean deleteData, boolean cascade) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
drop_database
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_databases(String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
get_databases
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_all_databases() throws org.apache.hadoop.hive.metastore.api.MetaException
get_all_databases
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public boolean create_type(org.apache.hadoop.hive.metastore.api.Type type) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
create_type
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public org.apache.hadoop.hive.metastore.api.Type get_type(String name) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
get_type
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public boolean drop_type(String name) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
drop_type
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public Map<String,org.apache.hadoop.hive.metastore.api.Type> get_type_all(String name) throws org.apache.hadoop.hive.metastore.api.MetaException
get_type_all
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public void create_table(org.apache.hadoop.hive.metastore.api.Table tbl) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
create_table
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void create_table_with_environment_context(org.apache.hadoop.hive.metastore.api.Table tbl, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
create_table_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void create_table_with_constraints(org.apache.hadoop.hive.metastore.api.Table tbl, List<org.apache.hadoop.hive.metastore.api.SQLPrimaryKey> primaryKeys, List<org.apache.hadoop.hive.metastore.api.SQLForeignKey> foreignKeys, List<org.apache.hadoop.hive.metastore.api.SQLUniqueConstraint> uniqueConstraints, List<org.apache.hadoop.hive.metastore.api.SQLNotNullConstraint> notNullConstraints, List<org.apache.hadoop.hive.metastore.api.SQLDefaultConstraint> defaultConstraints, List<org.apache.hadoop.hive.metastore.api.SQLCheckConstraint> checkConstraints) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void drop_constraint(org.apache.hadoop.hive.metastore.api.DropConstraintRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_primary_key(org.apache.hadoop.hive.metastore.api.AddPrimaryKeyRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_foreign_key(org.apache.hadoop.hive.metastore.api.AddForeignKeyRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_unique_constraint(org.apache.hadoop.hive.metastore.api.AddUniqueConstraintRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_not_null_constraint(org.apache.hadoop.hive.metastore.api.AddNotNullConstraintRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_default_constraint(org.apache.hadoop.hive.metastore.api.AddDefaultConstraintRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void add_check_constraint(org.apache.hadoop.hive.metastore.api.AddCheckConstraintRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
public void drop_table(String dbname, String name, boolean deleteData) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
drop_table
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public void drop_table_with_environment_context(String dbname, String name, boolean deleteData, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
drop_table_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.CmRecycleResponse cm_recycle(org.apache.hadoop.hive.metastore.api.CmRecycleRequest request) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public void truncate_table(String dbName, String tableName, List<String> partNames) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
@Deprecated public org.apache.hadoop.hive.metastore.api.Table get_table(String dbname, String name) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
get_table
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public org.apache.hadoop.hive.metastore.api.GetTableResult get_table_req(org.apache.hadoop.hive.metastore.api.GetTableRequest req) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public List<org.apache.hadoop.hive.metastore.api.TableMeta> get_table_meta(String dbnames, String tblNames, List<String> tblTypes) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public 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
IHMSHandler
get_table_core
in interface IHMSHandler
catName
- catalog namedbname
- database namename
- table nameorg.apache.hadoop.hive.metastore.api.MetaException
- If another error occurs.org.apache.hadoop.hive.metastore.api.NoSuchObjectException
- If the table does not exist.@Deprecated public List<org.apache.hadoop.hive.metastore.api.Table> get_table_objects_by_name(String dbName, List<String> tableNames) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_table_objects_by_name
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
dbName
- The name of the database in which the tables residetableNames
- The names of the tables to get.org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public org.apache.hadoop.hive.metastore.api.GetTablesResult get_table_objects_by_name_req(org.apache.hadoop.hive.metastore.api.GetTablesRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Materialization get_materialization_invalidation_info(org.apache.hadoop.hive.metastore.api.CreationMetadata cm, String validTxnList) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public void update_creation_metadata(String catName, String dbName, String tableName, org.apache.hadoop.hive.metastore.api.CreationMetadata cm) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_table_names_by_filter(String dbName, String filter, short maxTables) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_table_names_by_filter
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public org.apache.hadoop.hive.metastore.api.Partition append_partition(String dbName, String tableName, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException
append_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.Partition append_partition_with_environment_context(String dbName, String tableName, List<String> part_vals, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException
append_partition_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.AddPartitionsResult add_partitions_req(org.apache.hadoop.hive.metastore.api.AddPartitionsRequest request) throws org.apache.thrift.TException
add_partitions_req
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public int add_partitions(List<org.apache.hadoop.hive.metastore.api.Partition> parts) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.AlreadyExistsException
add_partitions
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
public int add_partitions_pspec(List<org.apache.hadoop.hive.metastore.api.PartitionSpec> partSpecs) throws org.apache.thrift.TException
add_partitions_pspec
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Partition add_partition(org.apache.hadoop.hive.metastore.api.Partition part) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException
add_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.Partition add_partition_with_environment_context(org.apache.hadoop.hive.metastore.api.Partition part, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.MetaException
add_partition_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.Partition exchange_partition(Map<String,String> partitionSpecs, String sourceDbName, String sourceTableName, String destDbName, String destTableName) throws org.apache.thrift.TException
exchange_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> exchange_partitions(Map<String,String> partitionSpecs, String sourceDbName, String sourceTableName, String destDbName, String destTableName) throws org.apache.thrift.TException
org.apache.thrift.TException
public boolean drop_partition(String db_name, String tbl_name, List<String> part_vals, boolean deleteData) throws org.apache.thrift.TException
drop_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.DropPartitionsResult drop_partitions_req(org.apache.hadoop.hive.metastore.api.DropPartitionsRequest request) throws org.apache.thrift.TException
drop_partitions_req
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean drop_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.thrift.TException
drop_partition_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Partition get_partition(String db_name, String tbl_name, List<String> part_vals) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException
get_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
public org.apache.hadoop.hive.metastore.api.Partition get_partition_with_auth(String db_name, String tbl_name, List<String> part_vals, String user_name, List<String> group_names) throws org.apache.thrift.TException
get_partition_with_auth
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions(String db_name, String tbl_name, short max_parts) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
get_partitions
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions_with_auth(String dbName, String tblName, short maxParts, String userName, List<String> groupNames) throws org.apache.thrift.TException
get_partitions_with_auth
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.PartitionSpec> get_partitions_pspec(String db_name, String tbl_name, int max_parts) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
get_partitions_pspec
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_partition_names(String db_name, String tbl_name, short max_parts) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException
get_partition_names
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.PartitionValuesResponse get_partition_values(org.apache.hadoop.hive.metastore.api.PartitionValuesRequest request) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public void alter_partition(String db_name, String tbl_name, org.apache.hadoop.hive.metastore.api.Partition new_part) throws org.apache.thrift.TException
alter_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void alter_partition_with_environment_context(String dbName, String tableName, org.apache.hadoop.hive.metastore.api.Partition newPartition, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.thrift.TException
alter_partition_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void rename_partition(String db_name, String tbl_name, List<String> part_vals, org.apache.hadoop.hive.metastore.api.Partition new_part) throws org.apache.thrift.TException
rename_partition
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void alter_partitions(String db_name, String tbl_name, List<org.apache.hadoop.hive.metastore.api.Partition> new_parts) throws org.apache.thrift.TException
alter_partitions
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void alter_partitions_with_environment_context(String db_name, String tbl_name, List<org.apache.hadoop.hive.metastore.api.Partition> new_parts, org.apache.hadoop.hive.metastore.api.EnvironmentContext environmentContext) throws org.apache.thrift.TException
org.apache.thrift.TException
public String getVersion() throws org.apache.thrift.TException
getVersion
in interface com.facebook.fb303.FacebookService.Iface
org.apache.thrift.TException
public void alter_table(String dbname, String name, org.apache.hadoop.hive.metastore.api.Table newTable) throws org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
alter_table
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
public void alter_table_with_cascade(String dbname, String name, org.apache.hadoop.hive.metastore.api.Table newTable, boolean cascade) throws org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
alter_table_with_cascade
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
public void alter_table_with_environment_context(String dbname, String name, org.apache.hadoop.hive.metastore.api.Table newTable, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException
alter_table_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_tables(String dbname, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
get_tables
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_tables_by_type(String dbname, String pattern, String tableType) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_materialized_views_for_rewriting(String dbname) throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public List<String> get_all_tables(String dbname) throws org.apache.hadoop.hive.metastore.api.MetaException
get_all_tables
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public List<org.apache.hadoop.hive.metastore.api.FieldSchema> get_fields(String db, String tableName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_fields
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.UnknownTableException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public List<org.apache.hadoop.hive.metastore.api.FieldSchema> get_fields_with_environment_context(String db, String tableName, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_fields_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.UnknownTableException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public List<org.apache.hadoop.hive.metastore.api.FieldSchema> get_schema(String db, String tableName) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_schema
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
db
- Name of the databasetableName
- Name of the tableorg.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.UnknownTableException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public List<org.apache.hadoop.hive.metastore.api.FieldSchema> get_schema_with_environment_context(String db, String tableName, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.UnknownTableException, org.apache.hadoop.hive.metastore.api.UnknownDBException
get_schema_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
db
- Name of the databasetableName
- Name of the tableenvContext
- Store session based propertiesorg.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.UnknownTableException
org.apache.hadoop.hive.metastore.api.UnknownDBException
public String getCpuProfile(int profileDurationInSec) throws org.apache.thrift.TException
getCpuProfile
in interface com.facebook.fb303.FacebookService.Iface
org.apache.thrift.TException
public String get_config_value(String name, String defaultValue) throws org.apache.thrift.TException
get_config_value
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Partition get_partition_by_name(String db_name, String tbl_name, String part_name) throws org.apache.thrift.TException
get_partition_by_name
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Partition append_partition_by_name(String db_name, String tbl_name, String part_name) throws org.apache.thrift.TException
append_partition_by_name
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.Partition append_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, org.apache.hadoop.hive.metastore.api.EnvironmentContext env_context) throws org.apache.thrift.TException
append_partition_by_name_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean drop_partition_by_name(String db_name, String tbl_name, String part_name, boolean deleteData) throws org.apache.thrift.TException
drop_partition_by_name
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean drop_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, boolean deleteData, org.apache.hadoop.hive.metastore.api.EnvironmentContext envContext) throws org.apache.thrift.TException
drop_partition_by_name_with_environment_context
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts) throws org.apache.thrift.TException
get_partitions_ps
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions_ps_with_auth(String db_name, String tbl_name, List<String> part_vals, short max_parts, String userName, List<String> groupNames) throws org.apache.thrift.TException
get_partitions_ps_with_auth
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<String> get_partition_names_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts) throws org.apache.thrift.TException
get_partition_names_ps
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<String> partition_name_to_vals(String part_name) throws org.apache.thrift.TException
partition_name_to_vals
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public Map<String,String> partition_name_to_spec(String part_name) throws org.apache.thrift.TException
partition_name_to_spec
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ColumnStatistics get_table_column_statistics(String dbName, String tableName, String colName) throws org.apache.thrift.TException
get_table_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.TableStatsResult get_table_statistics_req(org.apache.hadoop.hive.metastore.api.TableStatsRequest request) throws org.apache.thrift.TException
get_table_statistics_req
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ColumnStatistics get_partition_column_statistics(String dbName, String tableName, String partName, String colName) throws org.apache.thrift.TException
get_partition_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.PartitionsStatsResult get_partitions_statistics_req(org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest request) throws org.apache.thrift.TException
get_partitions_statistics_req
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean update_table_column_statistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats) throws org.apache.thrift.TException
update_table_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean update_partition_column_statistics(org.apache.hadoop.hive.metastore.api.ColumnStatistics colStats) throws org.apache.thrift.TException
update_partition_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean delete_partition_column_statistics(String dbName, String tableName, String partName, String colName) throws org.apache.thrift.TException
delete_partition_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean delete_table_column_statistics(String dbName, String tableName, String colName) throws org.apache.thrift.TException
delete_table_column_statistics
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions_by_filter(String dbName, String tblName, String filter, short maxParts) throws org.apache.thrift.TException
get_partitions_by_filter
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.PartitionSpec> get_part_specs_by_filter(String dbName, String tblName, String filter, int maxParts) throws org.apache.thrift.TException
get_part_specs_by_filter
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.PartitionsByExprResult get_partitions_by_expr(org.apache.hadoop.hive.metastore.api.PartitionsByExprRequest req) throws org.apache.thrift.TException
get_partitions_by_expr
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public int get_num_partitions_by_filter(String dbName, String tblName, String filter) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Partition> get_partitions_by_names(String dbName, String tblName, List<String> partNames) throws org.apache.thrift.TException
get_partitions_by_names
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.PrincipalPrivilegeSet get_privilege_set(org.apache.hadoop.hive.metastore.api.HiveObjectRef hiveObject, String userName, List<String> groupNames) throws org.apache.thrift.TException
get_privilege_set
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean grant_role(String roleName, String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, String grantor, org.apache.hadoop.hive.metastore.api.PrincipalType grantorType, boolean grantOption) throws org.apache.thrift.TException
grant_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.Role> list_roles(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType) throws org.apache.thrift.TException
list_roles
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean create_role(org.apache.hadoop.hive.metastore.api.Role role) throws org.apache.thrift.TException
create_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean drop_role(String roleName) throws org.apache.thrift.TException
drop_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<String> get_role_names() throws org.apache.thrift.TException
get_role_names
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean grant_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges) throws org.apache.thrift.TException
grant_privileges
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean revoke_role(String roleName, String userName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType) throws org.apache.thrift.TException
revoke_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GrantRevokeRoleResponse grant_revoke_role(org.apache.hadoop.hive.metastore.api.GrantRevokeRoleRequest request) throws org.apache.thrift.TException
grant_revoke_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse grant_revoke_privileges(org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest request) throws org.apache.thrift.TException
grant_revoke_privileges
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeResponse refresh_privileges(org.apache.hadoop.hive.metastore.api.HiveObjectRef objToRefresh, String authorizer, org.apache.hadoop.hive.metastore.api.GrantRevokePrivilegeRequest grantRequest) throws org.apache.thrift.TException
org.apache.thrift.TException
public boolean revoke_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges) throws org.apache.thrift.TException
revoke_privileges
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean revoke_privileges(org.apache.hadoop.hive.metastore.api.PrivilegeBag privileges, boolean grantOption) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.HiveObjectPrivilege> list_privileges(String principalName, org.apache.hadoop.hive.metastore.api.PrincipalType principalType, org.apache.hadoop.hive.metastore.api.HiveObjectRef hiveObject) throws org.apache.thrift.TException
list_privileges
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void cancel_delegation_token(String token_str_form) throws org.apache.thrift.TException
cancel_delegation_token
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public long renew_delegation_token(String token_str_form) throws org.apache.thrift.TException
renew_delegation_token
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public String get_delegation_token(String token_owner, String renewer_kerberos_principal_name) throws org.apache.thrift.TException
get_delegation_token
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean add_token(String token_identifier, String delegation_token) throws org.apache.thrift.TException
org.apache.thrift.TException
public boolean remove_token(String token_identifier) throws org.apache.thrift.TException
org.apache.thrift.TException
public String get_token(String token_identifier) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<String> get_all_token_identifiers() throws org.apache.thrift.TException
org.apache.thrift.TException
public int add_master_key(String key) throws org.apache.thrift.TException
org.apache.thrift.TException
public void update_master_key(int seq_number, String key) throws org.apache.thrift.TException
org.apache.thrift.TException
public boolean remove_master_key(int key_seq) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<String> get_master_keys() throws org.apache.thrift.TException
org.apache.thrift.TException
public void markPartitionForEvent(String db_name, String tbl_name, Map<String,String> partName, org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) throws org.apache.thrift.TException
markPartitionForEvent
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean isPartitionMarkedForEvent(String db_name, String tbl_name, Map<String,String> partName, org.apache.hadoop.hive.metastore.api.PartitionEventType evtType) throws org.apache.thrift.TException
isPartitionMarkedForEvent
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<String> set_ugi(String username, List<String> groupNames) throws org.apache.thrift.TException
set_ugi
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean partition_name_has_valid_characters(List<String> part_vals, boolean throw_exception) throws org.apache.thrift.TException
partition_name_has_valid_characters
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void create_function(org.apache.hadoop.hive.metastore.api.Function func) throws org.apache.thrift.TException
create_function
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void drop_function(String dbName, String funcName) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.InvalidInputException
drop_function
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.InvalidInputException
public void alter_function(String dbName, String funcName, org.apache.hadoop.hive.metastore.api.Function newFunc) throws org.apache.thrift.TException
alter_function
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public List<String> get_functions(String dbName, String pattern) throws org.apache.hadoop.hive.metastore.api.MetaException
get_functions
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.GetAllFunctionsResponse get_all_functions() throws org.apache.hadoop.hive.metastore.api.MetaException
org.apache.hadoop.hive.metastore.api.MetaException
public org.apache.hadoop.hive.metastore.api.Function get_function(String dbName, String funcName) throws org.apache.thrift.TException
get_function
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetOpenTxnsResponse get_open_txns() throws org.apache.thrift.TException
get_open_txns
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetOpenTxnsInfoResponse get_open_txns_info() throws org.apache.thrift.TException
get_open_txns_info
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.OpenTxnsResponse open_txns(org.apache.hadoop.hive.metastore.api.OpenTxnRequest rqst) throws org.apache.thrift.TException
open_txns
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void abort_txn(org.apache.hadoop.hive.metastore.api.AbortTxnRequest rqst) throws org.apache.thrift.TException
abort_txn
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void abort_txns(org.apache.hadoop.hive.metastore.api.AbortTxnsRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public void commit_txn(org.apache.hadoop.hive.metastore.api.CommitTxnRequest rqst) throws org.apache.thrift.TException
commit_txn
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void repl_tbl_writeid_state(org.apache.hadoop.hive.metastore.api.ReplTblWriteIdStateRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetValidWriteIdsResponse get_valid_write_ids(org.apache.hadoop.hive.metastore.api.GetValidWriteIdsRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.AllocateTableWriteIdsResponse allocate_table_write_ids(org.apache.hadoop.hive.metastore.api.AllocateTableWriteIdsRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.LockResponse lock(org.apache.hadoop.hive.metastore.api.LockRequest rqst) throws org.apache.thrift.TException
lock
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.LockResponse check_lock(org.apache.hadoop.hive.metastore.api.CheckLockRequest rqst) throws org.apache.thrift.TException
check_lock
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void unlock(org.apache.hadoop.hive.metastore.api.UnlockRequest rqst) throws org.apache.thrift.TException
unlock
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ShowLocksResponse show_locks(org.apache.hadoop.hive.metastore.api.ShowLocksRequest rqst) throws org.apache.thrift.TException
show_locks
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void heartbeat(org.apache.hadoop.hive.metastore.api.HeartbeatRequest ids) throws org.apache.thrift.TException
heartbeat
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeResponse heartbeat_txn_range(org.apache.hadoop.hive.metastore.api.HeartbeatTxnRangeRequest rqst) throws org.apache.thrift.TException
heartbeat_txn_range
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
@Deprecated public void compact(org.apache.hadoop.hive.metastore.api.CompactionRequest rqst) throws org.apache.thrift.TException
compact
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.CompactionResponse compact2(org.apache.hadoop.hive.metastore.api.CompactionRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ShowCompactResponse show_compact(org.apache.hadoop.hive.metastore.api.ShowCompactRequest rqst) throws org.apache.thrift.TException
show_compact
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public void flushCache() throws org.apache.thrift.TException
org.apache.thrift.TException
public void add_dynamic_partitions(org.apache.hadoop.hive.metastore.api.AddDynamicPartitions rqst) throws org.apache.thrift.TException
add_dynamic_partitions
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleResponse get_principals_in_role(org.apache.hadoop.hive.metastore.api.GetPrincipalsInRoleRequest request) throws org.apache.thrift.TException
get_principals_in_role
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalResponse get_role_grants_for_principal(org.apache.hadoop.hive.metastore.api.GetRoleGrantsForPrincipalRequest request) throws org.apache.thrift.TException
get_role_grants_for_principal
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.AggrStats get_aggr_stats_for(org.apache.hadoop.hive.metastore.api.PartitionsStatsRequest request) throws org.apache.thrift.TException
get_aggr_stats_for
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public boolean set_aggr_stats_for(org.apache.hadoop.hive.metastore.api.SetPartitionsStatsRequest request) throws org.apache.thrift.TException
set_aggr_stats_for
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.NotificationEventResponse get_next_notification(org.apache.hadoop.hive.metastore.api.NotificationEventRequest rqst) throws org.apache.thrift.TException
get_next_notification
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.CurrentNotificationEventId get_current_notificationEventId() throws org.apache.thrift.TException
get_current_notificationEventId
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.NotificationEventsCountResponse get_notification_events_count(org.apache.hadoop.hive.metastore.api.NotificationEventsCountRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.FireEventResponse fire_listener_event(org.apache.hadoop.hive.metastore.api.FireEventRequest rqst) throws org.apache.thrift.TException
fire_listener_event
in interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprResult get_file_metadata_by_expr(org.apache.hadoop.hive.metastore.api.GetFileMetadataByExprRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.GetFileMetadataResult get_file_metadata(org.apache.hadoop.hive.metastore.api.GetFileMetadataRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.PutFileMetadataResult put_file_metadata(org.apache.hadoop.hive.metastore.api.PutFileMetadataRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ClearFileMetadataResult clear_file_metadata(org.apache.hadoop.hive.metastore.api.ClearFileMetadataRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.CacheFileMetadataResult cache_file_metadata(org.apache.hadoop.hive.metastore.api.CacheFileMetadataRequest req) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.PrimaryKeysResponse get_primary_keys(org.apache.hadoop.hive.metastore.api.PrimaryKeysRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ForeignKeysResponse get_foreign_keys(org.apache.hadoop.hive.metastore.api.ForeignKeysRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.UniqueConstraintsResponse get_unique_constraints(org.apache.hadoop.hive.metastore.api.UniqueConstraintsRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.NotNullConstraintsResponse get_not_null_constraints(org.apache.hadoop.hive.metastore.api.NotNullConstraintsRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.DefaultConstraintsResponse get_default_constraints(org.apache.hadoop.hive.metastore.api.DefaultConstraintsRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.CheckConstraintsResponse get_check_constraints(org.apache.hadoop.hive.metastore.api.CheckConstraintsRequest request) throws org.apache.thrift.TException
org.apache.thrift.TException
public String get_metastore_db_uuid() throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMCreateResourcePlanResponse create_resource_plan(org.apache.hadoop.hive.metastore.api.WMCreateResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMGetResourcePlanResponse get_resource_plan(org.apache.hadoop.hive.metastore.api.WMGetResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMGetAllResourcePlanResponse get_all_resource_plans(org.apache.hadoop.hive.metastore.api.WMGetAllResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMAlterResourcePlanResponse alter_resource_plan(org.apache.hadoop.hive.metastore.api.WMAlterResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMGetActiveResourcePlanResponse get_active_resource_plan(org.apache.hadoop.hive.metastore.api.WMGetActiveResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMValidateResourcePlanResponse validate_resource_plan(org.apache.hadoop.hive.metastore.api.WMValidateResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMDropResourcePlanResponse drop_resource_plan(org.apache.hadoop.hive.metastore.api.WMDropResourcePlanRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMCreateTriggerResponse create_wm_trigger(org.apache.hadoop.hive.metastore.api.WMCreateTriggerRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMAlterTriggerResponse alter_wm_trigger(org.apache.hadoop.hive.metastore.api.WMAlterTriggerRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMDropTriggerResponse drop_wm_trigger(org.apache.hadoop.hive.metastore.api.WMDropTriggerRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMGetTriggersForResourePlanResponse get_triggers_for_resourceplan(org.apache.hadoop.hive.metastore.api.WMGetTriggersForResourePlanRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMAlterPoolResponse alter_wm_pool(org.apache.hadoop.hive.metastore.api.WMAlterPoolRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMCreatePoolResponse create_wm_pool(org.apache.hadoop.hive.metastore.api.WMCreatePoolRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMDropPoolResponse drop_wm_pool(org.apache.hadoop.hive.metastore.api.WMDropPoolRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMCreateOrUpdateMappingResponse create_or_update_wm_mapping(org.apache.hadoop.hive.metastore.api.WMCreateOrUpdateMappingRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMDropMappingResponse drop_wm_mapping(org.apache.hadoop.hive.metastore.api.WMDropMappingRequest request) throws org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidOperationException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidOperationException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.WMCreateOrDropTriggerToPoolMappingResponse create_or_drop_wm_trigger_to_pool_mapping(org.apache.hadoop.hive.metastore.api.WMCreateOrDropTriggerToPoolMappingRequest request) throws org.apache.hadoop.hive.metastore.api.AlreadyExistsException, org.apache.hadoop.hive.metastore.api.NoSuchObjectException, org.apache.hadoop.hive.metastore.api.InvalidObjectException, org.apache.hadoop.hive.metastore.api.MetaException, org.apache.thrift.TException
org.apache.hadoop.hive.metastore.api.AlreadyExistsException
org.apache.hadoop.hive.metastore.api.NoSuchObjectException
org.apache.hadoop.hive.metastore.api.InvalidObjectException
org.apache.hadoop.hive.metastore.api.MetaException
org.apache.thrift.TException
public void create_ischema(org.apache.hadoop.hive.metastore.api.ISchema schema) throws org.apache.thrift.TException
org.apache.thrift.TException
public void alter_ischema(org.apache.hadoop.hive.metastore.api.AlterISchemaRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.ISchema get_ischema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.thrift.TException
org.apache.thrift.TException
public void drop_ischema(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.thrift.TException
org.apache.thrift.TException
public void add_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersion schemaVersion) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.SchemaVersion get_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.SchemaVersion get_schema_latest_version(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.SchemaVersion> get_schema_all_versions(org.apache.hadoop.hive.metastore.api.ISchemaName schemaName) throws org.apache.thrift.TException
org.apache.thrift.TException
public void drop_schema_version(org.apache.hadoop.hive.metastore.api.SchemaVersionDescriptor version) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.FindSchemasByColsResp get_schemas_by_cols(org.apache.hadoop.hive.metastore.api.FindSchemasByColsRqst rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public void map_schema_version_to_serde(org.apache.hadoop.hive.metastore.api.MapSchemaVersionToSerdeRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public void set_schema_version_state(org.apache.hadoop.hive.metastore.api.SetSchemaVersionStateRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public void add_serde(org.apache.hadoop.hive.metastore.api.SerDeInfo serde) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.SerDeInfo get_serde(org.apache.hadoop.hive.metastore.api.GetSerdeRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
public org.apache.hadoop.hive.metastore.api.LockResponse get_lock_materialization_rebuild(String dbName, String tableName, long txnId) throws org.apache.thrift.TException
org.apache.thrift.TException
public boolean heartbeat_lock_materialization_rebuild(String dbName, String tableName, long txnId) throws org.apache.thrift.TException
org.apache.thrift.TException
public void add_runtime_stats(org.apache.hadoop.hive.metastore.api.RuntimeStat stat) throws org.apache.thrift.TException
org.apache.thrift.TException
public List<org.apache.hadoop.hive.metastore.api.RuntimeStat> get_runtime_stats(org.apache.hadoop.hive.metastore.api.GetRuntimeStatsRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TException
Copyright © 2019 The Apache Software Foundation. All Rights Reserved.