org.apache.hadoop.hive.service
Class ThriftHive.AsyncClient
java.lang.Object
org.apache.thrift.async.TAsyncClient
com.facebook.fb303.FacebookService.AsyncClient
org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient
org.apache.hadoop.hive.service.ThriftHive.AsyncClient
- All Implemented Interfaces:
- com.facebook.fb303.FacebookService.AsyncIface, ThriftHiveMetastore.AsyncIface, ThriftHive.AsyncIface
- Enclosing class:
- ThriftHive
public static class ThriftHive.AsyncClient
- extends ThriftHiveMetastore.AsyncClient
- implements ThriftHive.AsyncIface
Nested classes/interfaces inherited from class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient |
ThriftHiveMetastore.AsyncClient.add_index_call, ThriftHiveMetastore.AsyncClient.add_partition_call, ThriftHiveMetastore.AsyncClient.add_partition_with_environment_context_call, ThriftHiveMetastore.AsyncClient.add_partitions_call, ThriftHiveMetastore.AsyncClient.alter_database_call, ThriftHiveMetastore.AsyncClient.alter_index_call, ThriftHiveMetastore.AsyncClient.alter_partition_call, ThriftHiveMetastore.AsyncClient.alter_partition_with_environment_context_call, ThriftHiveMetastore.AsyncClient.alter_partitions_call, ThriftHiveMetastore.AsyncClient.alter_table_call, ThriftHiveMetastore.AsyncClient.alter_table_with_environment_context_call, ThriftHiveMetastore.AsyncClient.append_partition_by_name_call, ThriftHiveMetastore.AsyncClient.append_partition_call, ThriftHiveMetastore.AsyncClient.cancel_delegation_token_call, ThriftHiveMetastore.AsyncClient.create_database_call, ThriftHiveMetastore.AsyncClient.create_role_call, ThriftHiveMetastore.AsyncClient.create_table_call, ThriftHiveMetastore.AsyncClient.create_table_with_environment_context_call, ThriftHiveMetastore.AsyncClient.create_type_call, ThriftHiveMetastore.AsyncClient.delete_partition_column_statistics_call, ThriftHiveMetastore.AsyncClient.delete_table_column_statistics_call, ThriftHiveMetastore.AsyncClient.drop_database_call, ThriftHiveMetastore.AsyncClient.drop_index_by_name_call, ThriftHiveMetastore.AsyncClient.drop_partition_by_name_call, ThriftHiveMetastore.AsyncClient.drop_partition_call, ThriftHiveMetastore.AsyncClient.drop_role_call, ThriftHiveMetastore.AsyncClient.drop_table_call, ThriftHiveMetastore.AsyncClient.drop_type_call, ThriftHiveMetastore.AsyncClient.get_all_databases_call, ThriftHiveMetastore.AsyncClient.get_all_tables_call, ThriftHiveMetastore.AsyncClient.get_config_value_call, ThriftHiveMetastore.AsyncClient.get_database_call, ThriftHiveMetastore.AsyncClient.get_databases_call, ThriftHiveMetastore.AsyncClient.get_delegation_token_call, ThriftHiveMetastore.AsyncClient.get_fields_call, ThriftHiveMetastore.AsyncClient.get_index_by_name_call, ThriftHiveMetastore.AsyncClient.get_index_names_call, ThriftHiveMetastore.AsyncClient.get_indexes_call, ThriftHiveMetastore.AsyncClient.get_partition_by_name_call, ThriftHiveMetastore.AsyncClient.get_partition_call, ThriftHiveMetastore.AsyncClient.get_partition_column_statistics_call, ThriftHiveMetastore.AsyncClient.get_partition_names_call, ThriftHiveMetastore.AsyncClient.get_partition_names_ps_call, ThriftHiveMetastore.AsyncClient.get_partition_with_auth_call, ThriftHiveMetastore.AsyncClient.get_partitions_by_filter_call, ThriftHiveMetastore.AsyncClient.get_partitions_by_names_call, ThriftHiveMetastore.AsyncClient.get_partitions_call, ThriftHiveMetastore.AsyncClient.get_partitions_ps_call, ThriftHiveMetastore.AsyncClient.get_partitions_ps_with_auth_call, ThriftHiveMetastore.AsyncClient.get_partitions_with_auth_call, ThriftHiveMetastore.AsyncClient.get_privilege_set_call, ThriftHiveMetastore.AsyncClient.get_role_names_call, ThriftHiveMetastore.AsyncClient.get_schema_call, ThriftHiveMetastore.AsyncClient.get_table_call, ThriftHiveMetastore.AsyncClient.get_table_column_statistics_call, ThriftHiveMetastore.AsyncClient.get_table_names_by_filter_call, ThriftHiveMetastore.AsyncClient.get_table_objects_by_name_call, ThriftHiveMetastore.AsyncClient.get_tables_call, ThriftHiveMetastore.AsyncClient.get_type_all_call, ThriftHiveMetastore.AsyncClient.get_type_call, ThriftHiveMetastore.AsyncClient.grant_privileges_call, ThriftHiveMetastore.AsyncClient.grant_role_call, ThriftHiveMetastore.AsyncClient.isPartitionMarkedForEvent_call, ThriftHiveMetastore.AsyncClient.list_privileges_call, ThriftHiveMetastore.AsyncClient.list_roles_call, ThriftHiveMetastore.AsyncClient.markPartitionForEvent_call, ThriftHiveMetastore.AsyncClient.partition_name_to_spec_call, ThriftHiveMetastore.AsyncClient.partition_name_to_vals_call, ThriftHiveMetastore.AsyncClient.rename_partition_call, ThriftHiveMetastore.AsyncClient.renew_delegation_token_call, ThriftHiveMetastore.AsyncClient.revoke_privileges_call, ThriftHiveMetastore.AsyncClient.revoke_role_call, ThriftHiveMetastore.AsyncClient.set_ugi_call, ThriftHiveMetastore.AsyncClient.update_partition_column_statistics_call, ThriftHiveMetastore.AsyncClient.update_table_column_statistics_call |
Nested classes/interfaces inherited from class com.facebook.fb303.FacebookService.AsyncClient |
com.facebook.fb303.FacebookService.AsyncClient.aliveSince_call, com.facebook.fb303.FacebookService.AsyncClient.getCounter_call, com.facebook.fb303.FacebookService.AsyncClient.getCounters_call, com.facebook.fb303.FacebookService.AsyncClient.getCpuProfile_call, com.facebook.fb303.FacebookService.AsyncClient.getName_call, com.facebook.fb303.FacebookService.AsyncClient.getOption_call, com.facebook.fb303.FacebookService.AsyncClient.getOptions_call, com.facebook.fb303.FacebookService.AsyncClient.getStatus_call, com.facebook.fb303.FacebookService.AsyncClient.getStatusDetails_call, com.facebook.fb303.FacebookService.AsyncClient.getVersion_call, com.facebook.fb303.FacebookService.AsyncClient.reinitialize_call, com.facebook.fb303.FacebookService.AsyncClient.setOption_call, com.facebook.fb303.FacebookService.AsyncClient.shutdown_call |
Fields inherited from class org.apache.thrift.async.TAsyncClient |
___currentMethod, ___manager, ___protocolFactory, ___transport |
Constructor Summary |
ThriftHive.AsyncClient(org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.async.TAsyncClientManager clientManager,
org.apache.thrift.transport.TNonblockingTransport transport)
|
Methods inherited from class org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncClient |
add_index, add_partition_with_environment_context, add_partition, add_partitions, alter_database, alter_index, alter_partition_with_environment_context, alter_partition, alter_partitions, alter_table_with_environment_context, alter_table, append_partition_by_name, append_partition, cancel_delegation_token, create_database, create_role, create_table_with_environment_context, create_table, create_type, delete_partition_column_statistics, delete_table_column_statistics, drop_database, drop_index_by_name, drop_partition_by_name, drop_partition, drop_role, drop_table, drop_type, get_all_databases, get_all_tables, get_config_value, get_database, get_databases, get_delegation_token, get_fields, get_index_by_name, get_index_names, get_indexes, get_partition_by_name, get_partition_column_statistics, get_partition_names_ps, get_partition_names, get_partition_with_auth, get_partition, get_partitions_by_filter, get_partitions_by_names, get_partitions_ps_with_auth, get_partitions_ps, get_partitions_with_auth, get_partitions, get_privilege_set, get_role_names, get_schema, get_table_column_statistics, get_table_names_by_filter, get_table_objects_by_name, get_table, get_tables, get_type_all, get_type, grant_privileges, grant_role, isPartitionMarkedForEvent, list_privileges, list_roles, markPartitionForEvent, partition_name_to_spec, partition_name_to_vals, rename_partition, renew_delegation_token, revoke_privileges, revoke_role, set_ugi, update_partition_column_statistics, update_table_column_statistics |
Methods inherited from class com.facebook.fb303.FacebookService.AsyncClient |
aliveSince, getCounter, getCounters, getCpuProfile, getName, getOption, getOptions, getStatus, getStatusDetails, getVersion, reinitialize, setOption, shutdown |
Methods inherited from class org.apache.thrift.async.TAsyncClient |
checkReady, getError, getProtocolFactory, getTimeout, hasError, hasTimeout, onComplete, onError, setTimeout |
Methods inherited from class java.lang.Object |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait |
Methods inherited from interface org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncIface |
add_index, add_partition_with_environment_context, add_partition, add_partitions, alter_database, alter_index, alter_partition_with_environment_context, alter_partition, alter_partitions, alter_table_with_environment_context, alter_table, append_partition_by_name, append_partition, cancel_delegation_token, create_database, create_role, create_table_with_environment_context, create_table, create_type, delete_partition_column_statistics, delete_table_column_statistics, drop_database, drop_index_by_name, drop_partition_by_name, drop_partition, drop_role, drop_table, drop_type, get_all_databases, get_all_tables, get_config_value, get_database, get_databases, get_delegation_token, get_fields, get_index_by_name, get_index_names, get_indexes, get_partition_by_name, get_partition_column_statistics, get_partition_names_ps, get_partition_names, get_partition_with_auth, get_partition, get_partitions_by_filter, get_partitions_by_names, get_partitions_ps_with_auth, get_partitions_ps, get_partitions_with_auth, get_partitions, get_privilege_set, get_role_names, get_schema, get_table_column_statistics, get_table_names_by_filter, get_table_objects_by_name, get_table, get_tables, get_type_all, get_type, grant_privileges, grant_role, isPartitionMarkedForEvent, list_privileges, list_roles, markPartitionForEvent, partition_name_to_spec, partition_name_to_vals, rename_partition, renew_delegation_token, revoke_privileges, revoke_role, set_ugi, update_partition_column_statistics, update_table_column_statistics |
Methods inherited from interface com.facebook.fb303.FacebookService.AsyncIface |
aliveSince, getCounter, getCounters, getCpuProfile, getName, getOption, getOptions, getStatus, getStatusDetails, getVersion, reinitialize, setOption, shutdown |
ThriftHive.AsyncClient
public ThriftHive.AsyncClient(org.apache.thrift.protocol.TProtocolFactory protocolFactory,
org.apache.thrift.async.TAsyncClientManager clientManager,
org.apache.thrift.transport.TNonblockingTransport transport)
execute
public void execute(String query,
org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.execute_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
execute
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
fetchOne
public void fetchOne(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.fetchOne_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
fetchOne
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
fetchN
public void fetchN(int numRows,
org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.fetchN_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
fetchN
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
fetchAll
public void fetchAll(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.fetchAll_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
fetchAll
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
getSchema
public void getSchema(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.getSchema_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
getSchema
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
getThriftSchema
public void getThriftSchema(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.getThriftSchema_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
getThriftSchema
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
getClusterStatus
public void getClusterStatus(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.getClusterStatus_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
getClusterStatus
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
getQueryPlan
public void getQueryPlan(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.getQueryPlan_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
getQueryPlan
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
clean
public void clean(org.apache.thrift.async.AsyncMethodCallback<ThriftHive.AsyncClient.clean_call> resultHandler)
throws org.apache.thrift.TException
- Specified by:
clean
in interface ThriftHive.AsyncIface
- Throws:
org.apache.thrift.TException
Copyright © 2013 The Apache Software Foundation