public static interface ThriftHiveMetastore.Iface
extends com.facebook.fb303.FacebookService.Iface
String getMetaConf(String key) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionvoid setMetaConf(String key, String value) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionvoid create_database(Database database) throws AlreadyExistsException, InvalidObjectException, MetaException, org.apache.thrift.TException
AlreadyExistsExceptionInvalidObjectExceptionMetaExceptionorg.apache.thrift.TExceptionDatabase get_database(String name) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionvoid drop_database(String name, boolean deleteData, boolean cascade) throws NoSuchObjectException, InvalidOperationException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionInvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_databases(String pattern) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<String> get_all_databases() throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionvoid alter_database(String dbname, Database db) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionType get_type(String name) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionboolean create_type(Type type) throws AlreadyExistsException, InvalidObjectException, MetaException, org.apache.thrift.TException
AlreadyExistsExceptionInvalidObjectExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_type(String type) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionMap<String,Type> get_type_all(String name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<FieldSchema> get_fields(String db_name, String table_name) throws MetaException, UnknownTableException, UnknownDBException, org.apache.thrift.TException
MetaExceptionUnknownTableExceptionUnknownDBExceptionorg.apache.thrift.TExceptionList<FieldSchema> get_fields_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context) throws MetaException, UnknownTableException, UnknownDBException, org.apache.thrift.TException
MetaExceptionUnknownTableExceptionUnknownDBExceptionorg.apache.thrift.TExceptionList<FieldSchema> get_schema(String db_name, String table_name) throws MetaException, UnknownTableException, UnknownDBException, org.apache.thrift.TException
MetaExceptionUnknownTableExceptionUnknownDBExceptionorg.apache.thrift.TExceptionList<FieldSchema> get_schema_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context) throws MetaException, UnknownTableException, UnknownDBException, org.apache.thrift.TException
MetaExceptionUnknownTableExceptionUnknownDBExceptionorg.apache.thrift.TExceptionvoid create_table(Table tbl) throws AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException, org.apache.thrift.TException
AlreadyExistsExceptionInvalidObjectExceptionMetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionvoid create_table_with_environment_context(Table tbl, EnvironmentContext environment_context) throws AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException, org.apache.thrift.TException
AlreadyExistsExceptionInvalidObjectExceptionMetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionvoid drop_table(String dbname, String name, boolean deleteData) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionvoid drop_table_with_environment_context(String dbname, String name, boolean deleteData, EnvironmentContext environment_context) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_tables(String db_name, String pattern) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<String> get_all_tables(String db_name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionTable get_table(String dbname, String tbl_name) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Table> get_table_objects_by_name(String dbname, List<String> tbl_names) throws MetaException, InvalidOperationException, UnknownDBException, org.apache.thrift.TException
MetaExceptionInvalidOperationExceptionUnknownDBExceptionorg.apache.thrift.TExceptionList<String> get_table_names_by_filter(String dbname, String filter, short max_tables) throws MetaException, InvalidOperationException, UnknownDBException, org.apache.thrift.TException
MetaExceptionInvalidOperationExceptionUnknownDBExceptionorg.apache.thrift.TExceptionvoid alter_table(String dbname, String tbl_name, Table new_tbl) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_table_with_environment_context(String dbname, String tbl_name, Table new_tbl, EnvironmentContext environment_context) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_table_with_cascade(String dbname, String tbl_name, Table new_tbl, boolean cascade) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionPartition add_partition(Partition new_part) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionPartition add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionint add_partitions(List<Partition> new_parts) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionint add_partitions_pspec(List<PartitionSpec> new_parts) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionPartition append_partition(String db_name, String tbl_name, List<String> part_vals) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionAddPartitionsResult add_partitions_req(AddPartitionsRequest request) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionPartition append_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, EnvironmentContext environment_context) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionPartition append_partition_by_name(String db_name, String tbl_name, String part_name) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionPartition append_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, EnvironmentContext environment_context) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_partition(String db_name, String tbl_name, List<String> part_vals, boolean deleteData) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, EnvironmentContext environment_context) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_partition_by_name(String db_name, String tbl_name, String part_name, boolean deleteData) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, boolean deleteData, EnvironmentContext environment_context) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionDropPartitionsResult drop_partitions_req(DropPartitionsRequest req) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionPartition get_partition(String db_name, String tbl_name, List<String> part_vals) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionPartition exchange_partition(Map<String,String> partitionSpecs, String source_db, String source_table_name, String dest_db, String dest_table_name) throws MetaException, NoSuchObjectException, InvalidObjectException, InvalidInputException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionInvalidObjectExceptionInvalidInputExceptionorg.apache.thrift.TExceptionPartition get_partition_with_auth(String db_name, String tbl_name, List<String> part_vals, String user_name, List<String> group_names) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionPartition get_partition_by_name(String db_name, String tbl_name, String part_name) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions(String db_name, String tbl_name, short max_parts) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions_with_auth(String db_name, String tbl_name, short max_parts, String user_name, List<String> group_names) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<PartitionSpec> get_partitions_pspec(String db_name, String tbl_name, int max_parts) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_partition_names(String db_name, String tbl_name, short max_parts) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions_ps_with_auth(String db_name, String tbl_name, List<String> part_vals, short max_parts, String user_name, List<String> group_names) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_partition_names_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions_by_filter(String db_name, String tbl_name, String filter, short max_parts) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<PartitionSpec> get_part_specs_by_filter(String db_name, String tbl_name, String filter, int max_parts) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionPartitionsByExprResult get_partitions_by_expr(PartitionsByExprRequest req) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Partition> get_partitions_by_names(String db_name, String tbl_name, List<String> names) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionvoid alter_partition(String db_name, String tbl_name, Partition new_part) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_partitions(String db_name, String tbl_name, List<Partition> new_parts) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_partition_with_environment_context(String db_name, String tbl_name, Partition new_part, EnvironmentContext environment_context) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionvoid rename_partition(String db_name, String tbl_name, List<String> part_vals, Partition new_part) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionboolean partition_name_has_valid_characters(List<String> part_vals, boolean throw_exception) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionString get_config_value(String name, String defaultValue) throws ConfigValSecurityException, org.apache.thrift.TException
ConfigValSecurityExceptionorg.apache.thrift.TExceptionList<String> partition_name_to_vals(String part_name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionMap<String,String> partition_name_to_spec(String part_name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionvoid markPartitionForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType) throws MetaException, NoSuchObjectException, UnknownDBException, UnknownTableException, UnknownPartitionException, InvalidPartitionException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionUnknownDBExceptionUnknownTableExceptionUnknownPartitionExceptionInvalidPartitionExceptionorg.apache.thrift.TExceptionboolean isPartitionMarkedForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType) throws MetaException, NoSuchObjectException, UnknownDBException, UnknownTableException, UnknownPartitionException, InvalidPartitionException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionUnknownDBExceptionUnknownTableExceptionUnknownPartitionExceptionInvalidPartitionExceptionorg.apache.thrift.TExceptionIndex add_index(Index new_index, Table index_table) throws InvalidObjectException, AlreadyExistsException, MetaException, org.apache.thrift.TException
InvalidObjectExceptionAlreadyExistsExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_index(String dbname, String base_tbl_name, String idx_name, Index new_idx) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionboolean drop_index_by_name(String db_name, String tbl_name, String index_name, boolean deleteData) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionIndex get_index_by_name(String db_name, String tbl_name, String index_name) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionList<Index> get_indexes(String db_name, String tbl_name, short max_indexes) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_index_names(String db_name, String tbl_name, short max_indexes) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean update_table_column_statistics(ColumnStatistics stats_obj) throws NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException, org.apache.thrift.TException
NoSuchObjectExceptionInvalidObjectExceptionMetaExceptionInvalidInputExceptionorg.apache.thrift.TExceptionboolean update_partition_column_statistics(ColumnStatistics stats_obj) throws NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException, org.apache.thrift.TException
NoSuchObjectExceptionInvalidObjectExceptionMetaExceptionInvalidInputExceptionorg.apache.thrift.TExceptionColumnStatistics get_table_column_statistics(String db_name, String tbl_name, String col_name) throws NoSuchObjectException, MetaException, InvalidInputException, InvalidObjectException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionInvalidInputExceptionInvalidObjectExceptionorg.apache.thrift.TExceptionColumnStatistics get_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name) throws NoSuchObjectException, MetaException, InvalidInputException, InvalidObjectException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionInvalidInputExceptionInvalidObjectExceptionorg.apache.thrift.TExceptionTableStatsResult get_table_statistics_req(TableStatsRequest request) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionPartitionsStatsResult get_partitions_statistics_req(PartitionsStatsRequest request) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionAggrStats get_aggr_stats_for(PartitionsStatsRequest request) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionboolean set_aggr_stats_for(SetPartitionsStatsRequest request) throws NoSuchObjectException, InvalidObjectException, MetaException, InvalidInputException, org.apache.thrift.TException
NoSuchObjectExceptionInvalidObjectExceptionMetaExceptionInvalidInputExceptionorg.apache.thrift.TExceptionboolean delete_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name) throws NoSuchObjectException, MetaException, InvalidObjectException, InvalidInputException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionInvalidObjectExceptionInvalidInputExceptionorg.apache.thrift.TExceptionboolean delete_table_column_statistics(String db_name, String tbl_name, String col_name) throws NoSuchObjectException, MetaException, InvalidObjectException, InvalidInputException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionInvalidObjectExceptionInvalidInputExceptionorg.apache.thrift.TExceptionvoid create_function(Function func) throws AlreadyExistsException, InvalidObjectException, MetaException, NoSuchObjectException, org.apache.thrift.TException
AlreadyExistsExceptionInvalidObjectExceptionMetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionvoid drop_function(String dbName, String funcName) throws NoSuchObjectException, MetaException, org.apache.thrift.TException
NoSuchObjectExceptionMetaExceptionorg.apache.thrift.TExceptionvoid alter_function(String dbName, String funcName, Function newFunc) throws InvalidOperationException, MetaException, org.apache.thrift.TException
InvalidOperationExceptionMetaExceptionorg.apache.thrift.TExceptionList<String> get_functions(String dbName, String pattern) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionFunction get_function(String dbName, String funcName) throws MetaException, NoSuchObjectException, org.apache.thrift.TException
MetaExceptionNoSuchObjectExceptionorg.apache.thrift.TExceptionboolean create_role(Role role) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean drop_role(String role_name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<String> get_role_names() throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean grant_role(String role_name, String principal_name, PrincipalType principal_type, String grantor, PrincipalType grantorType, boolean grant_option) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean revoke_role(String role_name, String principal_name, PrincipalType principal_type) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<Role> list_roles(String principal_name, PrincipalType principal_type) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionGrantRevokeRoleResponse grant_revoke_role(GrantRevokeRoleRequest request) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionGetPrincipalsInRoleResponse get_principals_in_role(GetPrincipalsInRoleRequest request) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionGetRoleGrantsForPrincipalResponse get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionPrincipalPrivilegeSet get_privilege_set(HiveObjectRef hiveObject, String user_name, List<String> group_names) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<HiveObjectPrivilege> list_privileges(String principal_name, PrincipalType principal_type, HiveObjectRef hiveObject) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean grant_privileges(PrivilegeBag privileges) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionboolean revoke_privileges(PrivilegeBag privileges) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionGrantRevokePrivilegeResponse grant_revoke_privileges(GrantRevokePrivilegeRequest request) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionList<String> set_ugi(String user_name, List<String> group_names) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionString get_delegation_token(String token_owner, String renewer_kerberos_principal_name) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionlong renew_delegation_token(String token_str_form) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionvoid cancel_delegation_token(String token_str_form) throws MetaException, org.apache.thrift.TException
MetaExceptionorg.apache.thrift.TExceptionGetOpenTxnsResponse get_open_txns() throws org.apache.thrift.TException
org.apache.thrift.TExceptionGetOpenTxnsInfoResponse get_open_txns_info() throws org.apache.thrift.TException
org.apache.thrift.TExceptionOpenTxnsResponse open_txns(OpenTxnRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid abort_txn(AbortTxnRequest rqst) throws NoSuchTxnException, org.apache.thrift.TException
NoSuchTxnExceptionorg.apache.thrift.TExceptionvoid commit_txn(CommitTxnRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException
NoSuchTxnExceptionTxnAbortedExceptionorg.apache.thrift.TExceptionLockResponse lock(LockRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException
NoSuchTxnExceptionTxnAbortedExceptionorg.apache.thrift.TExceptionLockResponse check_lock(CheckLockRequest rqst) throws NoSuchTxnException, TxnAbortedException, NoSuchLockException, org.apache.thrift.TException
NoSuchTxnExceptionTxnAbortedExceptionNoSuchLockExceptionorg.apache.thrift.TExceptionvoid unlock(UnlockRequest rqst) throws NoSuchLockException, TxnOpenException, org.apache.thrift.TException
NoSuchLockExceptionTxnOpenExceptionorg.apache.thrift.TExceptionShowLocksResponse show_locks(ShowLocksRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid heartbeat(HeartbeatRequest ids) throws NoSuchLockException, NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException
NoSuchLockExceptionNoSuchTxnExceptionTxnAbortedExceptionorg.apache.thrift.TExceptionHeartbeatTxnRangeResponse heartbeat_txn_range(HeartbeatTxnRangeRequest txns) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid compact(CompactionRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionShowCompactResponse show_compact(ShowCompactRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionvoid add_dynamic_partitions(AddDynamicPartitions rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException
NoSuchTxnExceptionTxnAbortedExceptionorg.apache.thrift.TExceptionNotificationEventResponse get_next_notification(NotificationEventRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionCurrentNotificationEventId get_current_notificationEventId() throws org.apache.thrift.TException
org.apache.thrift.TExceptionFireEventResponse fire_listener_event(FireEventRequest rqst) throws org.apache.thrift.TException
org.apache.thrift.TExceptionCopyright © 2017 The Apache Software Foundation. All rights reserved.