You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by su...@apache.org on 2015/07/17 21:52:53 UTC

[01/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Repository: hive
Updated Branches:
  refs/heads/spark dddffe142 -> 42216997f


http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/hive_service/ThriftHive-remote
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/hive_service/ThriftHive-remote b/service/src/gen/thrift/gen-py/hive_service/ThriftHive-remote
old mode 100644
new mode 100755
index 1a5cf83..f580695
--- a/service/src/gen/thrift/gen-py/hive_service/ThriftHive-remote
+++ b/service/src/gen/thrift/gen-py/hive_service/ThriftHive-remote
@@ -1,6 +1,6 @@
 #!/usr/bin/env python
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -12,27 +12,164 @@ import pprint
 from urlparse import urlparse
 from thrift.transport import TTransport
 from thrift.transport import TSocket
+from thrift.transport import TSSLSocket
 from thrift.transport import THttpClient
 from thrift.protocol import TBinaryProtocol
 
-import ThriftHive
-from ttypes import *
+from hive_service import ThriftHive
+from hive_service.ttypes import *
 
 if len(sys.argv) <= 1 or sys.argv[1] == '--help':
-  print ''
-  print 'Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] function [arg1 [arg2...]]'
-  print ''
-  print 'Functions:'
-  print '  void execute(string query)'
-  print '  string fetchOne()'
-  print '   fetchN(i32 numRows)'
-  print '   fetchAll()'
-  print '  Schema getSchema()'
-  print '  Schema getThriftSchema()'
-  print '  HiveClusterStatus getClusterStatus()'
-  print '  QueryPlan getQueryPlan()'
-  print '  void clean()'
-  print ''
+  print('')
+  print('Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] [-s[sl]] function [arg1 [arg2...]]')
+  print('')
+  print('Functions:')
+  print('  void execute(string query)')
+  print('  string fetchOne()')
+  print('   fetchN(i32 numRows)')
+  print('   fetchAll()')
+  print('  Schema getSchema()')
+  print('  Schema getThriftSchema()')
+  print('  HiveClusterStatus getClusterStatus()')
+  print('  QueryPlan getQueryPlan()')
+  print('  void clean()')
+  print('  string getMetaConf(string key)')
+  print('  void setMetaConf(string key, string value)')
+  print('  void create_database(Database database)')
+  print('  Database get_database(string name)')
+  print('  void drop_database(string name, bool deleteData, bool cascade)')
+  print('   get_databases(string pattern)')
+  print('   get_all_databases()')
+  print('  void alter_database(string dbname, Database db)')
+  print('  Type get_type(string name)')
+  print('  bool create_type(Type type)')
+  print('  bool drop_type(string type)')
+  print('   get_type_all(string name)')
+  print('   get_fields(string db_name, string table_name)')
+  print('   get_fields_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)')
+  print('   get_schema(string db_name, string table_name)')
+  print('   get_schema_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)')
+  print('  void create_table(Table tbl)')
+  print('  void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context)')
+  print('  void drop_table(string dbname, string name, bool deleteData)')
+  print('  void drop_table_with_environment_context(string dbname, string name, bool deleteData, EnvironmentContext environment_context)')
+  print('   get_tables(string db_name, string pattern)')
+  print('   get_all_tables(string db_name)')
+  print('  Table get_table(string dbname, string tbl_name)')
+  print('   get_table_objects_by_name(string dbname,  tbl_names)')
+  print('   get_table_names_by_filter(string dbname, string filter, i16 max_tables)')
+  print('  void alter_table(string dbname, string tbl_name, Table new_tbl)')
+  print('  void alter_table_with_environment_context(string dbname, string tbl_name, Table new_tbl, EnvironmentContext environment_context)')
+  print('  void alter_table_with_cascade(string dbname, string tbl_name, Table new_tbl, bool cascade)')
+  print('  Partition add_partition(Partition new_part)')
+  print('  Partition add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context)')
+  print('  i32 add_partitions( new_parts)')
+  print('  i32 add_partitions_pspec( new_parts)')
+  print('  Partition append_partition(string db_name, string tbl_name,  part_vals)')
+  print('  AddPartitionsResult add_partitions_req(AddPartitionsRequest request)')
+  print('  Partition append_partition_with_environment_context(string db_name, string tbl_name,  part_vals, EnvironmentContext environment_context)')
+  print('  Partition append_partition_by_name(string db_name, string tbl_name, string part_name)')
+  print('  Partition append_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, EnvironmentContext environment_context)')
+  print('  bool drop_partition(string db_name, string tbl_name,  part_vals, bool deleteData)')
+  print('  bool drop_partition_with_environment_context(string db_name, string tbl_name,  part_vals, bool deleteData, EnvironmentContext environment_context)')
+  print('  bool drop_partition_by_name(string db_name, string tbl_name, string part_name, bool deleteData)')
+  print('  bool drop_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, bool deleteData, EnvironmentContext environment_context)')
+  print('  DropPartitionsResult drop_partitions_req(DropPartitionsRequest req)')
+  print('  Partition get_partition(string db_name, string tbl_name,  part_vals)')
+  print('  Partition exchange_partition( partitionSpecs, string source_db, string source_table_name, string dest_db, string dest_table_name)')
+  print('  Partition get_partition_with_auth(string db_name, string tbl_name,  part_vals, string user_name,  group_names)')
+  print('  Partition get_partition_by_name(string db_name, string tbl_name, string part_name)')
+  print('   get_partitions(string db_name, string tbl_name, i16 max_parts)')
+  print('   get_partitions_with_auth(string db_name, string tbl_name, i16 max_parts, string user_name,  group_names)')
+  print('   get_partitions_pspec(string db_name, string tbl_name, i32 max_parts)')
+  print('   get_partition_names(string db_name, string tbl_name, i16 max_parts)')
+  print('   get_partitions_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)')
+  print('   get_partitions_ps_with_auth(string db_name, string tbl_name,  part_vals, i16 max_parts, string user_name,  group_names)')
+  print('   get_partition_names_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)')
+  print('   get_partitions_by_filter(string db_name, string tbl_name, string filter, i16 max_parts)')
+  print('   get_part_specs_by_filter(string db_name, string tbl_name, string filter, i32 max_parts)')
+  print('  PartitionsByExprResult get_partitions_by_expr(PartitionsByExprRequest req)')
+  print('   get_partitions_by_names(string db_name, string tbl_name,  names)')
+  print('  void alter_partition(string db_name, string tbl_name, Partition new_part)')
+  print('  void alter_partitions(string db_name, string tbl_name,  new_parts)')
+  print('  void alter_partition_with_environment_context(string db_name, string tbl_name, Partition new_part, EnvironmentContext environment_context)')
+  print('  void rename_partition(string db_name, string tbl_name,  part_vals, Partition new_part)')
+  print('  bool partition_name_has_valid_characters( part_vals, bool throw_exception)')
+  print('  string get_config_value(string name, string defaultValue)')
+  print('   partition_name_to_vals(string part_name)')
+  print('   partition_name_to_spec(string part_name)')
+  print('  void markPartitionForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)')
+  print('  bool isPartitionMarkedForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)')
+  print('  Index add_index(Index new_index, Table index_table)')
+  print('  void alter_index(string dbname, string base_tbl_name, string idx_name, Index new_idx)')
+  print('  bool drop_index_by_name(string db_name, string tbl_name, string index_name, bool deleteData)')
+  print('  Index get_index_by_name(string db_name, string tbl_name, string index_name)')
+  print('   get_indexes(string db_name, string tbl_name, i16 max_indexes)')
+  print('   get_index_names(string db_name, string tbl_name, i16 max_indexes)')
+  print('  bool update_table_column_statistics(ColumnStatistics stats_obj)')
+  print('  bool update_partition_column_statistics(ColumnStatistics stats_obj)')
+  print('  ColumnStatistics get_table_column_statistics(string db_name, string tbl_name, string col_name)')
+  print('  ColumnStatistics get_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)')
+  print('  TableStatsResult get_table_statistics_req(TableStatsRequest request)')
+  print('  PartitionsStatsResult get_partitions_statistics_req(PartitionsStatsRequest request)')
+  print('  AggrStats get_aggr_stats_for(PartitionsStatsRequest request)')
+  print('  bool set_aggr_stats_for(SetPartitionsStatsRequest request)')
+  print('  bool delete_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)')
+  print('  bool delete_table_column_statistics(string db_name, string tbl_name, string col_name)')
+  print('  void create_function(Function func)')
+  print('  void drop_function(string dbName, string funcName)')
+  print('  void alter_function(string dbName, string funcName, Function newFunc)')
+  print('   get_functions(string dbName, string pattern)')
+  print('  Function get_function(string dbName, string funcName)')
+  print('  bool create_role(Role role)')
+  print('  bool drop_role(string role_name)')
+  print('   get_role_names()')
+  print('  bool grant_role(string role_name, string principal_name, PrincipalType principal_type, string grantor, PrincipalType grantorType, bool grant_option)')
+  print('  bool revoke_role(string role_name, string principal_name, PrincipalType principal_type)')
+  print('   list_roles(string principal_name, PrincipalType principal_type)')
+  print('  GrantRevokeRoleResponse grant_revoke_role(GrantRevokeRoleRequest request)')
+  print('  GetPrincipalsInRoleResponse get_principals_in_role(GetPrincipalsInRoleRequest request)')
+  print('  GetRoleGrantsForPrincipalResponse get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request)')
+  print('  PrincipalPrivilegeSet get_privilege_set(HiveObjectRef hiveObject, string user_name,  group_names)')
+  print('   list_privileges(string principal_name, PrincipalType principal_type, HiveObjectRef hiveObject)')
+  print('  bool grant_privileges(PrivilegeBag privileges)')
+  print('  bool revoke_privileges(PrivilegeBag privileges)')
+  print('  GrantRevokePrivilegeResponse grant_revoke_privileges(GrantRevokePrivilegeRequest request)')
+  print('   set_ugi(string user_name,  group_names)')
+  print('  string get_delegation_token(string token_owner, string renewer_kerberos_principal_name)')
+  print('  i64 renew_delegation_token(string token_str_form)')
+  print('  void cancel_delegation_token(string token_str_form)')
+  print('  GetOpenTxnsResponse get_open_txns()')
+  print('  GetOpenTxnsInfoResponse get_open_txns_info()')
+  print('  OpenTxnsResponse open_txns(OpenTxnRequest rqst)')
+  print('  void abort_txn(AbortTxnRequest rqst)')
+  print('  void commit_txn(CommitTxnRequest rqst)')
+  print('  LockResponse lock(LockRequest rqst)')
+  print('  LockResponse check_lock(CheckLockRequest rqst)')
+  print('  void unlock(UnlockRequest rqst)')
+  print('  ShowLocksResponse show_locks(ShowLocksRequest rqst)')
+  print('  void heartbeat(HeartbeatRequest ids)')
+  print('  HeartbeatTxnRangeResponse heartbeat_txn_range(HeartbeatTxnRangeRequest txns)')
+  print('  void compact(CompactionRequest rqst)')
+  print('  ShowCompactResponse show_compact(ShowCompactRequest rqst)')
+  print('  void add_dynamic_partitions(AddDynamicPartitions rqst)')
+  print('  NotificationEventResponse get_next_notification(NotificationEventRequest rqst)')
+  print('  CurrentNotificationEventId get_current_notificationEventId()')
+  print('  FireEventResponse fire_listener_event(FireEventRequest rqst)')
+  print('  string getName()')
+  print('  string getVersion()')
+  print('  fb_status getStatus()')
+  print('  string getStatusDetails()')
+  print('   getCounters()')
+  print('  i64 getCounter(string key)')
+  print('  void setOption(string key, string value)')
+  print('  string getOption(string key)')
+  print('   getOptions()')
+  print('  string getCpuProfile(i32 profileDurationInSec)')
+  print('  i64 aliveSince()')
+  print('  void reinitialize()')
+  print('  void shutdown()')
+  print('')
   sys.exit(0)
 
 pp = pprint.PrettyPrinter(indent = 2)
@@ -40,6 +177,7 @@ host = 'localhost'
 port = 9090
 uri = ''
 framed = False
+ssl = False
 http = False
 argi = 1
 
@@ -68,13 +206,17 @@ if sys.argv[argi] == '-f' or sys.argv[argi] == '-framed':
   framed = True
   argi += 1
 
+if sys.argv[argi] == '-s' or sys.argv[argi] == '-ssl':
+  ssl = True
+  argi += 1
+
 cmd = sys.argv[argi]
 args = sys.argv[argi+1:]
 
 if http:
   transport = THttpClient.THttpClient(host, port, uri)
 else:
-  socket = TSocket.TSocket(host, port)
+  socket = TSSLSocket.TSSLSocket(host, port, validate=False) if ssl else TSocket.TSocket(host, port)
   if framed:
     transport = TTransport.TFramedTransport(socket)
   else:
@@ -85,60 +227,876 @@ transport.open()
 
 if cmd == 'execute':
   if len(args) != 1:
-    print 'execute requires 1 args'
+    print('execute requires 1 args')
     sys.exit(1)
   pp.pprint(client.execute(args[0],))
 
 elif cmd == 'fetchOne':
   if len(args) != 0:
-    print 'fetchOne requires 0 args'
+    print('fetchOne requires 0 args')
     sys.exit(1)
   pp.pprint(client.fetchOne())
 
 elif cmd == 'fetchN':
   if len(args) != 1:
-    print 'fetchN requires 1 args'
+    print('fetchN requires 1 args')
     sys.exit(1)
   pp.pprint(client.fetchN(eval(args[0]),))
 
 elif cmd == 'fetchAll':
   if len(args) != 0:
-    print 'fetchAll requires 0 args'
+    print('fetchAll requires 0 args')
     sys.exit(1)
   pp.pprint(client.fetchAll())
 
 elif cmd == 'getSchema':
   if len(args) != 0:
-    print 'getSchema requires 0 args'
+    print('getSchema requires 0 args')
     sys.exit(1)
   pp.pprint(client.getSchema())
 
 elif cmd == 'getThriftSchema':
   if len(args) != 0:
-    print 'getThriftSchema requires 0 args'
+    print('getThriftSchema requires 0 args')
     sys.exit(1)
   pp.pprint(client.getThriftSchema())
 
 elif cmd == 'getClusterStatus':
   if len(args) != 0:
-    print 'getClusterStatus requires 0 args'
+    print('getClusterStatus requires 0 args')
     sys.exit(1)
   pp.pprint(client.getClusterStatus())
 
 elif cmd == 'getQueryPlan':
   if len(args) != 0:
-    print 'getQueryPlan requires 0 args'
+    print('getQueryPlan requires 0 args')
     sys.exit(1)
   pp.pprint(client.getQueryPlan())
 
 elif cmd == 'clean':
   if len(args) != 0:
-    print 'clean requires 0 args'
+    print('clean requires 0 args')
     sys.exit(1)
   pp.pprint(client.clean())
 
+elif cmd == 'getMetaConf':
+  if len(args) != 1:
+    print('getMetaConf requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getMetaConf(args[0],))
+
+elif cmd == 'setMetaConf':
+  if len(args) != 2:
+    print('setMetaConf requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.setMetaConf(args[0],args[1],))
+
+elif cmd == 'create_database':
+  if len(args) != 1:
+    print('create_database requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.create_database(eval(args[0]),))
+
+elif cmd == 'get_database':
+  if len(args) != 1:
+    print('get_database requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_database(args[0],))
+
+elif cmd == 'drop_database':
+  if len(args) != 3:
+    print('drop_database requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.drop_database(args[0],eval(args[1]),eval(args[2]),))
+
+elif cmd == 'get_databases':
+  if len(args) != 1:
+    print('get_databases requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_databases(args[0],))
+
+elif cmd == 'get_all_databases':
+  if len(args) != 0:
+    print('get_all_databases requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.get_all_databases())
+
+elif cmd == 'alter_database':
+  if len(args) != 2:
+    print('alter_database requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.alter_database(args[0],eval(args[1]),))
+
+elif cmd == 'get_type':
+  if len(args) != 1:
+    print('get_type requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_type(args[0],))
+
+elif cmd == 'create_type':
+  if len(args) != 1:
+    print('create_type requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.create_type(eval(args[0]),))
+
+elif cmd == 'drop_type':
+  if len(args) != 1:
+    print('drop_type requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.drop_type(args[0],))
+
+elif cmd == 'get_type_all':
+  if len(args) != 1:
+    print('get_type_all requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_type_all(args[0],))
+
+elif cmd == 'get_fields':
+  if len(args) != 2:
+    print('get_fields requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_fields(args[0],args[1],))
+
+elif cmd == 'get_fields_with_environment_context':
+  if len(args) != 3:
+    print('get_fields_with_environment_context requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_fields_with_environment_context(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_schema':
+  if len(args) != 2:
+    print('get_schema requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_schema(args[0],args[1],))
+
+elif cmd == 'get_schema_with_environment_context':
+  if len(args) != 3:
+    print('get_schema_with_environment_context requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_schema_with_environment_context(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'create_table':
+  if len(args) != 1:
+    print('create_table requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.create_table(eval(args[0]),))
+
+elif cmd == 'create_table_with_environment_context':
+  if len(args) != 2:
+    print('create_table_with_environment_context requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.create_table_with_environment_context(eval(args[0]),eval(args[1]),))
+
+elif cmd == 'drop_table':
+  if len(args) != 3:
+    print('drop_table requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.drop_table(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'drop_table_with_environment_context':
+  if len(args) != 4:
+    print('drop_table_with_environment_context requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.drop_table_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'get_tables':
+  if len(args) != 2:
+    print('get_tables requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_tables(args[0],args[1],))
+
+elif cmd == 'get_all_tables':
+  if len(args) != 1:
+    print('get_all_tables requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_all_tables(args[0],))
+
+elif cmd == 'get_table':
+  if len(args) != 2:
+    print('get_table requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_table(args[0],args[1],))
+
+elif cmd == 'get_table_objects_by_name':
+  if len(args) != 2:
+    print('get_table_objects_by_name requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_table_objects_by_name(args[0],eval(args[1]),))
+
+elif cmd == 'get_table_names_by_filter':
+  if len(args) != 3:
+    print('get_table_names_by_filter requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_table_names_by_filter(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'alter_table':
+  if len(args) != 3:
+    print('alter_table requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.alter_table(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'alter_table_with_environment_context':
+  if len(args) != 4:
+    print('alter_table_with_environment_context requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.alter_table_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'alter_table_with_cascade':
+  if len(args) != 4:
+    print('alter_table_with_cascade requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.alter_table_with_cascade(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'add_partition':
+  if len(args) != 1:
+    print('add_partition requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.add_partition(eval(args[0]),))
+
+elif cmd == 'add_partition_with_environment_context':
+  if len(args) != 2:
+    print('add_partition_with_environment_context requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.add_partition_with_environment_context(eval(args[0]),eval(args[1]),))
+
+elif cmd == 'add_partitions':
+  if len(args) != 1:
+    print('add_partitions requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.add_partitions(eval(args[0]),))
+
+elif cmd == 'add_partitions_pspec':
+  if len(args) != 1:
+    print('add_partitions_pspec requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.add_partitions_pspec(eval(args[0]),))
+
+elif cmd == 'append_partition':
+  if len(args) != 3:
+    print('append_partition requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.append_partition(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'add_partitions_req':
+  if len(args) != 1:
+    print('add_partitions_req requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.add_partitions_req(eval(args[0]),))
+
+elif cmd == 'append_partition_with_environment_context':
+  if len(args) != 4:
+    print('append_partition_with_environment_context requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.append_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'append_partition_by_name':
+  if len(args) != 3:
+    print('append_partition_by_name requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.append_partition_by_name(args[0],args[1],args[2],))
+
+elif cmd == 'append_partition_by_name_with_environment_context':
+  if len(args) != 4:
+    print('append_partition_by_name_with_environment_context requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.append_partition_by_name_with_environment_context(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'drop_partition':
+  if len(args) != 4:
+    print('drop_partition requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.drop_partition(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'drop_partition_with_environment_context':
+  if len(args) != 5:
+    print('drop_partition_with_environment_context requires 5 args')
+    sys.exit(1)
+  pp.pprint(client.drop_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),eval(args[4]),))
+
+elif cmd == 'drop_partition_by_name':
+  if len(args) != 4:
+    print('drop_partition_by_name requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.drop_partition_by_name(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'drop_partition_by_name_with_environment_context':
+  if len(args) != 5:
+    print('drop_partition_by_name_with_environment_context requires 5 args')
+    sys.exit(1)
+  pp.pprint(client.drop_partition_by_name_with_environment_context(args[0],args[1],args[2],eval(args[3]),eval(args[4]),))
+
+elif cmd == 'drop_partitions_req':
+  if len(args) != 1:
+    print('drop_partitions_req requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.drop_partitions_req(eval(args[0]),))
+
+elif cmd == 'get_partition':
+  if len(args) != 3:
+    print('get_partition requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'exchange_partition':
+  if len(args) != 5:
+    print('exchange_partition requires 5 args')
+    sys.exit(1)
+  pp.pprint(client.exchange_partition(eval(args[0]),args[1],args[2],args[3],args[4],))
+
+elif cmd == 'get_partition_with_auth':
+  if len(args) != 5:
+    print('get_partition_with_auth requires 5 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition_with_auth(args[0],args[1],eval(args[2]),args[3],eval(args[4]),))
+
+elif cmd == 'get_partition_by_name':
+  if len(args) != 3:
+    print('get_partition_by_name requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition_by_name(args[0],args[1],args[2],))
+
+elif cmd == 'get_partitions':
+  if len(args) != 3:
+    print('get_partitions requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_partitions_with_auth':
+  if len(args) != 5:
+    print('get_partitions_with_auth requires 5 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_with_auth(args[0],args[1],eval(args[2]),args[3],eval(args[4]),))
+
+elif cmd == 'get_partitions_pspec':
+  if len(args) != 3:
+    print('get_partitions_pspec requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_pspec(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_partition_names':
+  if len(args) != 3:
+    print('get_partition_names requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition_names(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_partitions_ps':
+  if len(args) != 4:
+    print('get_partitions_ps requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_ps(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'get_partitions_ps_with_auth':
+  if len(args) != 6:
+    print('get_partitions_ps_with_auth requires 6 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_ps_with_auth(args[0],args[1],eval(args[2]),eval(args[3]),args[4],eval(args[5]),))
+
+elif cmd == 'get_partition_names_ps':
+  if len(args) != 4:
+    print('get_partition_names_ps requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition_names_ps(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'get_partitions_by_filter':
+  if len(args) != 4:
+    print('get_partitions_by_filter requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_by_filter(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'get_part_specs_by_filter':
+  if len(args) != 4:
+    print('get_part_specs_by_filter requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.get_part_specs_by_filter(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'get_partitions_by_expr':
+  if len(args) != 1:
+    print('get_partitions_by_expr requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_by_expr(eval(args[0]),))
+
+elif cmd == 'get_partitions_by_names':
+  if len(args) != 3:
+    print('get_partitions_by_names requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_by_names(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'alter_partition':
+  if len(args) != 3:
+    print('alter_partition requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.alter_partition(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'alter_partitions':
+  if len(args) != 3:
+    print('alter_partitions requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.alter_partitions(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'alter_partition_with_environment_context':
+  if len(args) != 4:
+    print('alter_partition_with_environment_context requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.alter_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'rename_partition':
+  if len(args) != 4:
+    print('rename_partition requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.rename_partition(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'partition_name_has_valid_characters':
+  if len(args) != 2:
+    print('partition_name_has_valid_characters requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.partition_name_has_valid_characters(eval(args[0]),eval(args[1]),))
+
+elif cmd == 'get_config_value':
+  if len(args) != 2:
+    print('get_config_value requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_config_value(args[0],args[1],))
+
+elif cmd == 'partition_name_to_vals':
+  if len(args) != 1:
+    print('partition_name_to_vals requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.partition_name_to_vals(args[0],))
+
+elif cmd == 'partition_name_to_spec':
+  if len(args) != 1:
+    print('partition_name_to_spec requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.partition_name_to_spec(args[0],))
+
+elif cmd == 'markPartitionForEvent':
+  if len(args) != 4:
+    print('markPartitionForEvent requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.markPartitionForEvent(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'isPartitionMarkedForEvent':
+  if len(args) != 4:
+    print('isPartitionMarkedForEvent requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.isPartitionMarkedForEvent(args[0],args[1],eval(args[2]),eval(args[3]),))
+
+elif cmd == 'add_index':
+  if len(args) != 2:
+    print('add_index requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.add_index(eval(args[0]),eval(args[1]),))
+
+elif cmd == 'alter_index':
+  if len(args) != 4:
+    print('alter_index requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.alter_index(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'drop_index_by_name':
+  if len(args) != 4:
+    print('drop_index_by_name requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.drop_index_by_name(args[0],args[1],args[2],eval(args[3]),))
+
+elif cmd == 'get_index_by_name':
+  if len(args) != 3:
+    print('get_index_by_name requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_index_by_name(args[0],args[1],args[2],))
+
+elif cmd == 'get_indexes':
+  if len(args) != 3:
+    print('get_indexes requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_indexes(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_index_names':
+  if len(args) != 3:
+    print('get_index_names requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_index_names(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'update_table_column_statistics':
+  if len(args) != 1:
+    print('update_table_column_statistics requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.update_table_column_statistics(eval(args[0]),))
+
+elif cmd == 'update_partition_column_statistics':
+  if len(args) != 1:
+    print('update_partition_column_statistics requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.update_partition_column_statistics(eval(args[0]),))
+
+elif cmd == 'get_table_column_statistics':
+  if len(args) != 3:
+    print('get_table_column_statistics requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_table_column_statistics(args[0],args[1],args[2],))
+
+elif cmd == 'get_partition_column_statistics':
+  if len(args) != 4:
+    print('get_partition_column_statistics requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.get_partition_column_statistics(args[0],args[1],args[2],args[3],))
+
+elif cmd == 'get_table_statistics_req':
+  if len(args) != 1:
+    print('get_table_statistics_req requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_table_statistics_req(eval(args[0]),))
+
+elif cmd == 'get_partitions_statistics_req':
+  if len(args) != 1:
+    print('get_partitions_statistics_req requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_partitions_statistics_req(eval(args[0]),))
+
+elif cmd == 'get_aggr_stats_for':
+  if len(args) != 1:
+    print('get_aggr_stats_for requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_aggr_stats_for(eval(args[0]),))
+
+elif cmd == 'set_aggr_stats_for':
+  if len(args) != 1:
+    print('set_aggr_stats_for requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.set_aggr_stats_for(eval(args[0]),))
+
+elif cmd == 'delete_partition_column_statistics':
+  if len(args) != 4:
+    print('delete_partition_column_statistics requires 4 args')
+    sys.exit(1)
+  pp.pprint(client.delete_partition_column_statistics(args[0],args[1],args[2],args[3],))
+
+elif cmd == 'delete_table_column_statistics':
+  if len(args) != 3:
+    print('delete_table_column_statistics requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.delete_table_column_statistics(args[0],args[1],args[2],))
+
+elif cmd == 'create_function':
+  if len(args) != 1:
+    print('create_function requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.create_function(eval(args[0]),))
+
+elif cmd == 'drop_function':
+  if len(args) != 2:
+    print('drop_function requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.drop_function(args[0],args[1],))
+
+elif cmd == 'alter_function':
+  if len(args) != 3:
+    print('alter_function requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.alter_function(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'get_functions':
+  if len(args) != 2:
+    print('get_functions requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_functions(args[0],args[1],))
+
+elif cmd == 'get_function':
+  if len(args) != 2:
+    print('get_function requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_function(args[0],args[1],))
+
+elif cmd == 'create_role':
+  if len(args) != 1:
+    print('create_role requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.create_role(eval(args[0]),))
+
+elif cmd == 'drop_role':
+  if len(args) != 1:
+    print('drop_role requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.drop_role(args[0],))
+
+elif cmd == 'get_role_names':
+  if len(args) != 0:
+    print('get_role_names requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.get_role_names())
+
+elif cmd == 'grant_role':
+  if len(args) != 6:
+    print('grant_role requires 6 args')
+    sys.exit(1)
+  pp.pprint(client.grant_role(args[0],args[1],eval(args[2]),args[3],eval(args[4]),eval(args[5]),))
+
+elif cmd == 'revoke_role':
+  if len(args) != 3:
+    print('revoke_role requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.revoke_role(args[0],args[1],eval(args[2]),))
+
+elif cmd == 'list_roles':
+  if len(args) != 2:
+    print('list_roles requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.list_roles(args[0],eval(args[1]),))
+
+elif cmd == 'grant_revoke_role':
+  if len(args) != 1:
+    print('grant_revoke_role requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.grant_revoke_role(eval(args[0]),))
+
+elif cmd == 'get_principals_in_role':
+  if len(args) != 1:
+    print('get_principals_in_role requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_principals_in_role(eval(args[0]),))
+
+elif cmd == 'get_role_grants_for_principal':
+  if len(args) != 1:
+    print('get_role_grants_for_principal requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_role_grants_for_principal(eval(args[0]),))
+
+elif cmd == 'get_privilege_set':
+  if len(args) != 3:
+    print('get_privilege_set requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.get_privilege_set(eval(args[0]),args[1],eval(args[2]),))
+
+elif cmd == 'list_privileges':
+  if len(args) != 3:
+    print('list_privileges requires 3 args')
+    sys.exit(1)
+  pp.pprint(client.list_privileges(args[0],eval(args[1]),eval(args[2]),))
+
+elif cmd == 'grant_privileges':
+  if len(args) != 1:
+    print('grant_privileges requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.grant_privileges(eval(args[0]),))
+
+elif cmd == 'revoke_privileges':
+  if len(args) != 1:
+    print('revoke_privileges requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.revoke_privileges(eval(args[0]),))
+
+elif cmd == 'grant_revoke_privileges':
+  if len(args) != 1:
+    print('grant_revoke_privileges requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.grant_revoke_privileges(eval(args[0]),))
+
+elif cmd == 'set_ugi':
+  if len(args) != 2:
+    print('set_ugi requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.set_ugi(args[0],eval(args[1]),))
+
+elif cmd == 'get_delegation_token':
+  if len(args) != 2:
+    print('get_delegation_token requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.get_delegation_token(args[0],args[1],))
+
+elif cmd == 'renew_delegation_token':
+  if len(args) != 1:
+    print('renew_delegation_token requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.renew_delegation_token(args[0],))
+
+elif cmd == 'cancel_delegation_token':
+  if len(args) != 1:
+    print('cancel_delegation_token requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.cancel_delegation_token(args[0],))
+
+elif cmd == 'get_open_txns':
+  if len(args) != 0:
+    print('get_open_txns requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.get_open_txns())
+
+elif cmd == 'get_open_txns_info':
+  if len(args) != 0:
+    print('get_open_txns_info requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.get_open_txns_info())
+
+elif cmd == 'open_txns':
+  if len(args) != 1:
+    print('open_txns requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.open_txns(eval(args[0]),))
+
+elif cmd == 'abort_txn':
+  if len(args) != 1:
+    print('abort_txn requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.abort_txn(eval(args[0]),))
+
+elif cmd == 'commit_txn':
+  if len(args) != 1:
+    print('commit_txn requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.commit_txn(eval(args[0]),))
+
+elif cmd == 'lock':
+  if len(args) != 1:
+    print('lock requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.lock(eval(args[0]),))
+
+elif cmd == 'check_lock':
+  if len(args) != 1:
+    print('check_lock requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.check_lock(eval(args[0]),))
+
+elif cmd == 'unlock':
+  if len(args) != 1:
+    print('unlock requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.unlock(eval(args[0]),))
+
+elif cmd == 'show_locks':
+  if len(args) != 1:
+    print('show_locks requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.show_locks(eval(args[0]),))
+
+elif cmd == 'heartbeat':
+  if len(args) != 1:
+    print('heartbeat requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.heartbeat(eval(args[0]),))
+
+elif cmd == 'heartbeat_txn_range':
+  if len(args) != 1:
+    print('heartbeat_txn_range requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.heartbeat_txn_range(eval(args[0]),))
+
+elif cmd == 'compact':
+  if len(args) != 1:
+    print('compact requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.compact(eval(args[0]),))
+
+elif cmd == 'show_compact':
+  if len(args) != 1:
+    print('show_compact requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.show_compact(eval(args[0]),))
+
+elif cmd == 'add_dynamic_partitions':
+  if len(args) != 1:
+    print('add_dynamic_partitions requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.add_dynamic_partitions(eval(args[0]),))
+
+elif cmd == 'get_next_notification':
+  if len(args) != 1:
+    print('get_next_notification requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.get_next_notification(eval(args[0]),))
+
+elif cmd == 'get_current_notificationEventId':
+  if len(args) != 0:
+    print('get_current_notificationEventId requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.get_current_notificationEventId())
+
+elif cmd == 'fire_listener_event':
+  if len(args) != 1:
+    print('fire_listener_event requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.fire_listener_event(eval(args[0]),))
+
+elif cmd == 'getName':
+  if len(args) != 0:
+    print('getName requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getName())
+
+elif cmd == 'getVersion':
+  if len(args) != 0:
+    print('getVersion requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getVersion())
+
+elif cmd == 'getStatus':
+  if len(args) != 0:
+    print('getStatus requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getStatus())
+
+elif cmd == 'getStatusDetails':
+  if len(args) != 0:
+    print('getStatusDetails requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getStatusDetails())
+
+elif cmd == 'getCounters':
+  if len(args) != 0:
+    print('getCounters requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getCounters())
+
+elif cmd == 'getCounter':
+  if len(args) != 1:
+    print('getCounter requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getCounter(args[0],))
+
+elif cmd == 'setOption':
+  if len(args) != 2:
+    print('setOption requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.setOption(args[0],args[1],))
+
+elif cmd == 'getOption':
+  if len(args) != 1:
+    print('getOption requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getOption(args[0],))
+
+elif cmd == 'getOptions':
+  if len(args) != 0:
+    print('getOptions requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getOptions())
+
+elif cmd == 'getCpuProfile':
+  if len(args) != 1:
+    print('getCpuProfile requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getCpuProfile(eval(args[0]),))
+
+elif cmd == 'aliveSince':
+  if len(args) != 0:
+    print('aliveSince requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.aliveSince())
+
+elif cmd == 'reinitialize':
+  if len(args) != 0:
+    print('reinitialize requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.reinitialize())
+
+elif cmd == 'shutdown':
+  if len(args) != 0:
+    print('shutdown requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.shutdown())
+
 else:
-  print 'Unrecognized method %s' % cmd
+  print('Unrecognized method %s' % cmd)
   sys.exit(1)
 
 transport.close()

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/hive_service/ThriftHive.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/hive_service/ThriftHive.py b/service/src/gen/thrift/gen-py/hive_service/ThriftHive.py
index 33912f9..177531d 100644
--- a/service/src/gen/thrift/gen-py/hive_service/ThriftHive.py
+++ b/service/src/gen/thrift/gen-py/hive_service/ThriftHive.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -26,7 +26,7 @@ class Iface(hive_metastore.ThriftHiveMetastore.Iface):
     """
     pass
 
-  def fetchOne(self, ):
+  def fetchOne(self):
     pass
 
   def fetchN(self, numRows):
@@ -36,22 +36,22 @@ class Iface(hive_metastore.ThriftHiveMetastore.Iface):
     """
     pass
 
-  def fetchAll(self, ):
+  def fetchAll(self):
     pass
 
-  def getSchema(self, ):
+  def getSchema(self):
     pass
 
-  def getThriftSchema(self, ):
+  def getThriftSchema(self):
     pass
 
-  def getClusterStatus(self, ):
+  def getClusterStatus(self):
     pass
 
-  def getQueryPlan(self, ):
+  def getQueryPlan(self):
     pass
 
-  def clean(self, ):
+  def clean(self):
     pass
 
 
@@ -75,41 +75,43 @@ class Client(hive_metastore.ThriftHiveMetastore.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_execute(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_execute(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = execute_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.ex is not None:
       raise result.ex
     return
 
-  def fetchOne(self, ):
+  def fetchOne(self):
     self.send_fetchOne()
     return self.recv_fetchOne()
 
-  def send_fetchOne(self, ):
+  def send_fetchOne(self):
     self._oprot.writeMessageBegin('fetchOne', TMessageType.CALL, self._seqid)
     args = fetchOne_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_fetchOne(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_fetchOne(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = fetchOne_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
@@ -132,178 +134,185 @@ class Client(hive_metastore.ThriftHiveMetastore.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_fetchN(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_fetchN(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = fetchN_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "fetchN failed: unknown result");
 
-  def fetchAll(self, ):
+  def fetchAll(self):
     self.send_fetchAll()
     return self.recv_fetchAll()
 
-  def send_fetchAll(self, ):
+  def send_fetchAll(self):
     self._oprot.writeMessageBegin('fetchAll', TMessageType.CALL, self._seqid)
     args = fetchAll_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_fetchAll(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_fetchAll(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = fetchAll_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "fetchAll failed: unknown result");
 
-  def getSchema(self, ):
+  def getSchema(self):
     self.send_getSchema()
     return self.recv_getSchema()
 
-  def send_getSchema(self, ):
+  def send_getSchema(self):
     self._oprot.writeMessageBegin('getSchema', TMessageType.CALL, self._seqid)
     args = getSchema_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_getSchema(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_getSchema(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = getSchema_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "getSchema failed: unknown result");
 
-  def getThriftSchema(self, ):
+  def getThriftSchema(self):
     self.send_getThriftSchema()
     return self.recv_getThriftSchema()
 
-  def send_getThriftSchema(self, ):
+  def send_getThriftSchema(self):
     self._oprot.writeMessageBegin('getThriftSchema', TMessageType.CALL, self._seqid)
     args = getThriftSchema_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_getThriftSchema(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_getThriftSchema(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = getThriftSchema_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "getThriftSchema failed: unknown result");
 
-  def getClusterStatus(self, ):
+  def getClusterStatus(self):
     self.send_getClusterStatus()
     return self.recv_getClusterStatus()
 
-  def send_getClusterStatus(self, ):
+  def send_getClusterStatus(self):
     self._oprot.writeMessageBegin('getClusterStatus', TMessageType.CALL, self._seqid)
     args = getClusterStatus_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_getClusterStatus(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_getClusterStatus(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = getClusterStatus_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "getClusterStatus failed: unknown result");
 
-  def getQueryPlan(self, ):
+  def getQueryPlan(self):
     self.send_getQueryPlan()
     return self.recv_getQueryPlan()
 
-  def send_getQueryPlan(self, ):
+  def send_getQueryPlan(self):
     self._oprot.writeMessageBegin('getQueryPlan', TMessageType.CALL, self._seqid)
     args = getQueryPlan_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_getQueryPlan(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_getQueryPlan(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = getQueryPlan_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.ex is not None:
       raise result.ex
     raise TApplicationException(TApplicationException.MISSING_RESULT, "getQueryPlan failed: unknown result");
 
-  def clean(self, ):
+  def clean(self):
     self.send_clean()
     self.recv_clean()
 
-  def send_clean(self, ):
+  def send_clean(self):
     self._oprot.writeMessageBegin('clean', TMessageType.CALL, self._seqid)
     args = clean_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_clean(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_clean(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = clean_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     return
 
 
@@ -342,7 +351,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = execute_result()
     try:
       self._handler.execute(args.query)
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("execute", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -356,7 +365,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = fetchOne_result()
     try:
       result.success = self._handler.fetchOne()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("fetchOne", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -370,7 +379,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = fetchN_result()
     try:
       result.success = self._handler.fetchN(args.numRows)
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("fetchN", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -384,7 +393,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = fetchAll_result()
     try:
       result.success = self._handler.fetchAll()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("fetchAll", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -398,7 +407,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = getSchema_result()
     try:
       result.success = self._handler.getSchema()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("getSchema", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -412,7 +421,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = getThriftSchema_result()
     try:
       result.success = self._handler.getThriftSchema()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("getThriftSchema", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -426,7 +435,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = getClusterStatus_result()
     try:
       result.success = self._handler.getClusterStatus()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("getClusterStatus", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -440,7 +449,7 @@ class Processor(hive_metastore.ThriftHiveMetastore.Processor, Iface, TProcessor)
     result = getQueryPlan_result()
     try:
       result.success = self._handler.getQueryPlan()
-    except HiveServerException as ex:
+    except HiveServerException, ex:
       result.ex = ex
     oprot.writeMessageBegin("getQueryPlan", TMessageType.REPLY, seqid)
     result.write(oprot)
@@ -510,6 +519,11 @@ class execute_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.query)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -571,6 +585,11 @@ class execute_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -613,6 +632,10 @@ class fetchOne_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -685,6 +708,12 @@ class fetchOne_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -745,6 +774,11 @@ class fetchN_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.numRows)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -825,6 +859,12 @@ class fetchN_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -867,6 +907,10 @@ class fetchAll_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -947,6 +991,12 @@ class fetchAll_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -989,6 +1039,10 @@ class getSchema_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1062,6 +1116,12 @@ class getSchema_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1104,6 +1164,10 @@ class getThriftSchema_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1177,6 +1241,12 @@ class getThriftSchema_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1219,6 +1289,10 @@ class getClusterStatus_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1292,6 +1366,12 @@ class getClusterStatus_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1334,6 +1414,10 @@ class getQueryPlan_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1407,6 +1491,12 @@ class getQueryPlan_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    value = (value * 31) ^ hash(self.ex)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1449,6 +1539,10 @@ class clean_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1491,6 +1585,10 @@ class clean_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/hive_service/constants.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/hive_service/constants.py b/service/src/gen/thrift/gen-py/hive_service/constants.py
index a236326..99717a9 100644
--- a/service/src/gen/thrift/gen-py/hive_service/constants.py
+++ b/service/src/gen/thrift/gen-py/hive_service/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/hive_service/ttypes.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/hive_service/ttypes.py b/service/src/gen/thrift/gen-py/hive_service/ttypes.py
index e5f4095..29eb916 100644
--- a/service/src/gen/thrift/gen-py/hive_service/ttypes.py
+++ b/service/src/gen/thrift/gen-py/hive_service/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -144,6 +144,16 @@ class HiveClusterStatus:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.taskTrackers)
+    value = (value * 31) ^ hash(self.mapTasks)
+    value = (value * 31) ^ hash(self.reduceTasks)
+    value = (value * 31) ^ hash(self.maxMapTasks)
+    value = (value * 31) ^ hash(self.maxReduceTasks)
+    value = (value * 31) ^ hash(self.state)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -231,6 +241,13 @@ class HiveServerException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    value = (value * 31) ^ hash(self.errorCode)
+    value = (value * 31) ^ hash(self.SQLState)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/hive_service_constants.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/hive_service_constants.rb b/service/src/gen/thrift/gen-rb/hive_service_constants.rb
index 0f908b5..73f4d7b 100644
--- a/service/src/gen/thrift/gen-rb/hive_service_constants.rb
+++ b/service/src/gen/thrift/gen-rb/hive_service_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/hive_service_types.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/hive_service_types.rb b/service/src/gen/thrift/gen-rb/hive_service_types.rb
index e5913bd..f97a6fb 100644
--- a/service/src/gen/thrift/gen-rb/hive_service_types.rb
+++ b/service/src/gen/thrift/gen-rb/hive_service_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/t_c_l_i_service.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/t_c_l_i_service.rb b/service/src/gen/thrift/gen-rb/t_c_l_i_service.rb
index fd1ca9a..f754d7d 100644
--- a/service/src/gen/thrift/gen-rb/t_c_l_i_service.rb
+++ b/service/src/gen/thrift/gen-rb/t_c_l_i_service.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/t_c_l_i_service_constants.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/t_c_l_i_service_constants.rb b/service/src/gen/thrift/gen-rb/t_c_l_i_service_constants.rb
index 4b8ddae..3f72769 100644
--- a/service/src/gen/thrift/gen-rb/t_c_l_i_service_constants.rb
+++ b/service/src/gen/thrift/gen-rb/t_c_l_i_service_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/t_c_l_i_service_types.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/t_c_l_i_service_types.rb b/service/src/gen/thrift/gen-rb/t_c_l_i_service_types.rb
index b482533..bfb2b69 100644
--- a/service/src/gen/thrift/gen-rb/t_c_l_i_service_types.rb
+++ b/service/src/gen/thrift/gen-rb/t_c_l_i_service_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-rb/thrift_hive.rb
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-rb/thrift_hive.rb b/service/src/gen/thrift/gen-rb/thrift_hive.rb
index 8da94bb..6859ceb 100644
--- a/service/src/gen/thrift/gen-rb/thrift_hive.rb
+++ b/service/src/gen/thrift/gen-rb/thrift_hive.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #


[21/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning_2.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning_2.q.out b/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning_2.q.out
new file mode 100644
index 0000000..4e62a3b
--- /dev/null
+++ b/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning_2.q.out
@@ -0,0 +1,1015 @@
+PREHOOK: query: -- SORT_QUERY_RESULTS
+
+create table dim_shops (id int, label string) row format delimited fields terminated by ',' stored as textfile
+PREHOOK: type: CREATETABLE
+PREHOOK: Output: database:default
+PREHOOK: Output: default@dim_shops
+POSTHOOK: query: -- SORT_QUERY_RESULTS
+
+create table dim_shops (id int, label string) row format delimited fields terminated by ',' stored as textfile
+POSTHOOK: type: CREATETABLE
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@dim_shops
+PREHOOK: query: load data local inpath '../../data/files/dim_shops.txt' into table dim_shops
+PREHOOK: type: LOAD
+#### A masked pattern was here ####
+PREHOOK: Output: default@dim_shops
+POSTHOOK: query: load data local inpath '../../data/files/dim_shops.txt' into table dim_shops
+POSTHOOK: type: LOAD
+#### A masked pattern was here ####
+POSTHOOK: Output: default@dim_shops
+PREHOOK: query: create table agg_01 (amount decimal) partitioned by (dim_shops_id int) row format delimited fields terminated by ',' stored as textfile
+PREHOOK: type: CREATETABLE
+PREHOOK: Output: database:default
+PREHOOK: Output: default@agg_01
+POSTHOOK: query: create table agg_01 (amount decimal) partitioned by (dim_shops_id int) row format delimited fields terminated by ',' stored as textfile
+POSTHOOK: type: CREATETABLE
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@agg_01
+PREHOOK: query: alter table agg_01 add partition (dim_shops_id = 1)
+PREHOOK: type: ALTERTABLE_ADDPARTS
+PREHOOK: Output: default@agg_01
+POSTHOOK: query: alter table agg_01 add partition (dim_shops_id = 1)
+POSTHOOK: type: ALTERTABLE_ADDPARTS
+POSTHOOK: Output: default@agg_01
+POSTHOOK: Output: default@agg_01@dim_shops_id=1
+PREHOOK: query: alter table agg_01 add partition (dim_shops_id = 2)
+PREHOOK: type: ALTERTABLE_ADDPARTS
+PREHOOK: Output: default@agg_01
+POSTHOOK: query: alter table agg_01 add partition (dim_shops_id = 2)
+POSTHOOK: type: ALTERTABLE_ADDPARTS
+POSTHOOK: Output: default@agg_01
+POSTHOOK: Output: default@agg_01@dim_shops_id=2
+PREHOOK: query: alter table agg_01 add partition (dim_shops_id = 3)
+PREHOOK: type: ALTERTABLE_ADDPARTS
+PREHOOK: Output: default@agg_01
+POSTHOOK: query: alter table agg_01 add partition (dim_shops_id = 3)
+POSTHOOK: type: ALTERTABLE_ADDPARTS
+POSTHOOK: Output: default@agg_01
+POSTHOOK: Output: default@agg_01@dim_shops_id=3
+PREHOOK: query: load data local inpath '../../data/files/agg_01-p1.txt' into table agg_01 partition (dim_shops_id=1)
+PREHOOK: type: LOAD
+#### A masked pattern was here ####
+PREHOOK: Output: default@agg_01@dim_shops_id=1
+POSTHOOK: query: load data local inpath '../../data/files/agg_01-p1.txt' into table agg_01 partition (dim_shops_id=1)
+POSTHOOK: type: LOAD
+#### A masked pattern was here ####
+POSTHOOK: Output: default@agg_01@dim_shops_id=1
+PREHOOK: query: load data local inpath '../../data/files/agg_01-p2.txt' into table agg_01 partition (dim_shops_id=2)
+PREHOOK: type: LOAD
+#### A masked pattern was here ####
+PREHOOK: Output: default@agg_01@dim_shops_id=2
+POSTHOOK: query: load data local inpath '../../data/files/agg_01-p2.txt' into table agg_01 partition (dim_shops_id=2)
+POSTHOOK: type: LOAD
+#### A masked pattern was here ####
+POSTHOOK: Output: default@agg_01@dim_shops_id=2
+PREHOOK: query: load data local inpath '../../data/files/agg_01-p3.txt' into table agg_01 partition (dim_shops_id=3)
+PREHOOK: type: LOAD
+#### A masked pattern was here ####
+PREHOOK: Output: default@agg_01@dim_shops_id=3
+POSTHOOK: query: load data local inpath '../../data/files/agg_01-p3.txt' into table agg_01 partition (dim_shops_id=3)
+POSTHOOK: type: LOAD
+#### A masked pattern was here ####
+POSTHOOK: Output: default@agg_01@dim_shops_id=3
+PREHOOK: query: analyze table dim_shops compute statistics
+PREHOOK: type: QUERY
+PREHOOK: Input: default@dim_shops
+PREHOOK: Output: default@dim_shops
+POSTHOOK: query: analyze table dim_shops compute statistics
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@dim_shops
+POSTHOOK: Output: default@dim_shops
+PREHOOK: query: analyze table agg_01 partition (dim_shops_id) compute statistics
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Output: default@agg_01
+PREHOOK: Output: default@agg_01@dim_shops_id=1
+PREHOOK: Output: default@agg_01@dim_shops_id=2
+PREHOOK: Output: default@agg_01@dim_shops_id=3
+POSTHOOK: query: analyze table agg_01 partition (dim_shops_id) compute statistics
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Output: default@agg_01
+POSTHOOK: Output: default@agg_01@dim_shops_id=1
+POSTHOOK: Output: default@agg_01@dim_shops_id=2
+POSTHOOK: Output: default@agg_01@dim_shops_id=3
+PREHOOK: query: select * from dim_shops
+PREHOOK: type: QUERY
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: select * from dim_shops
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+1	foo
+2	bar
+3	baz
+PREHOOK: query: select * from agg_01
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+#### A masked pattern was here ####
+POSTHOOK: query: select * from agg_01
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+#### A masked pattern was here ####
+1	1
+2	1
+3	1
+4	2
+5	2
+6	2
+7	3
+8	3
+9	3
+PREHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: d1
+                  filterExpr: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+                    Select Operator
+                      expressions: id (type: int)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: int)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: dim_shops_id
+                          Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                          target column name: dim_shops_id
+                          target work: Map 1
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (GROUP, 2)
+        Reducer 3 <- Reducer 2 (SORT, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col0, _col1, _col5, _col6
+                    input vertices:
+                      1 Map 4
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: ((_col1 = _col5) and (_col6) IN ('foo', 'bar')) (type: boolean)
+                      Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col6 (type: string), _col0 (type: decimal(10,0))
+                        outputColumnNames: _col6, _col0
+                        Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                        Group By Operator
+                          aggregations: count(), sum(_col0)
+                          keys: _col6 (type: string)
+                          mode: hash
+                          outputColumnNames: _col0, _col1, _col2
+                          Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                          Reduce Output Operator
+                            key expressions: _col0 (type: string)
+                            sort order: +
+                            Map-reduce partition columns: _col0 (type: string)
+                            Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                            value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+            Local Work:
+              Map Reduce Local Work
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0), sum(VALUE._col1)
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col0 (type: string)
+                  sort order: +
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+        Reducer 3 
+            Reduce Operator Tree:
+              Select Operator
+                expressions: KEY.reducesinkkey0 (type: string), VALUE._col0 (type: bigint), VALUE._col1 (type: decimal(20,0))
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+bar	3	15
+foo	3	6
+PREHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: d1
+                  filterExpr: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (GROUP, 2)
+        Reducer 3 <- Reducer 2 (SORT, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col0, _col1, _col5, _col6
+                    input vertices:
+                      1 Map 4
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: ((_col1 = _col5) and (_col6) IN ('foo', 'bar')) (type: boolean)
+                      Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col6 (type: string), _col0 (type: decimal(10,0))
+                        outputColumnNames: _col6, _col0
+                        Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                        Group By Operator
+                          aggregations: count(), sum(_col0)
+                          keys: _col6 (type: string)
+                          mode: hash
+                          outputColumnNames: _col0, _col1, _col2
+                          Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                          Reduce Output Operator
+                            key expressions: _col0 (type: string)
+                            sort order: +
+                            Map-reduce partition columns: _col0 (type: string)
+                            Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                            value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+            Local Work:
+              Map Reduce Local Work
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0), sum(VALUE._col1)
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col0 (type: string)
+                  sort order: +
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+        Reducer 3 
+            Reduce Operator Tree:
+              Select Operator
+                expressions: KEY.reducesinkkey0 (type: string), VALUE._col0 (type: bigint), VALUE._col1 (type: decimal(20,0))
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+bar	3	15
+foo	3	6
+PREHOOK: query: EXPLAIN SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 2 
+            Map Operator Tree:
+                TableScan
+                  alias: d1
+                  filterExpr: id is not null (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: id is not null (type: boolean)
+                    Statistics: Num rows: 2 Data size: 10 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col1, _col5, _col6
+                    input vertices:
+                      1 Map 2
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: (_col1 = _col5) (type: boolean)
+                      Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col6 (type: string)
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                        File Output Operator
+                          compressed: false
+                          Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                          table:
+                              input format: org.apache.hadoop.mapred.TextInputFormat
+                              output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                              serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+bar
+bar
+bar
+baz
+baz
+baz
+foo
+foo
+foo
+PREHOOK: query: EXPLAIN SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 2 
+            Map Operator Tree:
+                TableScan
+                  alias: d1
+                  filterExpr: (id = 1) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id = 1) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 1 (type: int)
+                        1 1 (type: int)
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg
+                  filterExpr: (dim_shops_id = 1) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 1 (type: int)
+                      1 1 (type: int)
+                    outputColumnNames: _col0
+                    input vertices:
+                      1 Map 2
+                    Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
+                    File Output Operator
+                      compressed: false
+                      Statistics: Num rows: 3 Data size: 9 Basic stats: COMPLETE Column stats: NONE
+                      table:
+                          input format: org.apache.hadoop.mapred.TextInputFormat
+                          output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                          serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+1
+2
+3
+PREHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: d1
+                  filterExpr: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id is not null and (label) IN ('foo', 'bar')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+                    Select Operator
+                      expressions: id (type: int)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: int)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: dim_shops_id
+                          Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                          target column name: dim_shops_id
+                          target work: Map 1
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (GROUP, 2)
+        Reducer 3 <- Reducer 2 (SORT, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col0, _col1, _col5, _col6
+                    input vertices:
+                      1 Map 4
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: ((_col1 = _col5) and (_col6) IN ('foo', 'bar')) (type: boolean)
+                      Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col6 (type: string), _col0 (type: decimal(10,0))
+                        outputColumnNames: _col6, _col0
+                        Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                        Group By Operator
+                          aggregations: count(), sum(_col0)
+                          keys: _col6 (type: string)
+                          mode: hash
+                          outputColumnNames: _col0, _col1, _col2
+                          Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                          Reduce Output Operator
+                            key expressions: _col0 (type: string)
+                            sort order: +
+                            Map-reduce partition columns: _col0 (type: string)
+                            Statistics: Num rows: 2 Data size: 6 Basic stats: COMPLETE Column stats: NONE
+                            value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+            Local Work:
+              Map Reduce Local Work
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0), sum(VALUE._col1)
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col0 (type: string)
+                  sort order: +
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  value expressions: _col1 (type: bigint), _col2 (type: decimal(20,0))
+        Reducer 3 
+            Reduce Operator Tree:
+              Select Operator
+                expressions: KEY.reducesinkkey0 (type: string), VALUE._col0 (type: bigint), VALUE._col1 (type: decimal(20,0))
+                outputColumnNames: _col0, _col1, _col2
+                Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 3 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+bar	3	15
+foo	3	6
+PREHOOK: query: EXPLAIN 
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar'
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN 
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-3 depends on stages: Stage-2
+  Stage-1 depends on stages: Stage-3
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 2 
+            Map Operator Tree:
+                TableScan
+                  alias: dim_shops
+                  filterExpr: (id is not null and (label = 'foo')) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id is not null and (label = 'foo')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+                    Select Operator
+                      expressions: id (type: int)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: int)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: dim_shops_id
+                          Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                          target column name: dim_shops_id
+                          target work: Map 1
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-3
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: dim_shops
+                  filterExpr: (id is not null and (label = 'bar')) (type: boolean)
+                  Statistics: Num rows: 3 Data size: 15 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (id is not null and (label = 'bar')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Spark HashTable Sink Operator
+                      keys:
+                        0 dim_shops_id (type: int)
+                        1 id (type: int)
+                    Select Operator
+                      expressions: id (type: int)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: int)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: dim_shops_id
+                          Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                          target column name: dim_shops_id
+                          target work: Map 3
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-1
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: agg_01
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col0, _col1, _col5
+                    input vertices:
+                      1 Map 2
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: (_col1 = _col5) (type: boolean)
+                      Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col0 (type: decimal(10,0))
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                        File Output Operator
+                          compressed: false
+                          Statistics: Num rows: 8 Data size: 24 Basic stats: COMPLETE Column stats: NONE
+                          table:
+                              input format: org.apache.hadoop.mapred.TextInputFormat
+                              output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                              serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Local Work:
+              Map Reduce Local Work
+        Map 3 
+            Map Operator Tree:
+                TableScan
+                  alias: agg_01
+                  filterExpr: dim_shops_id is not null (type: boolean)
+                  Statistics: Num rows: 9 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                  Map Join Operator
+                    condition map:
+                         Inner Join 0 to 1
+                    keys:
+                      0 dim_shops_id (type: int)
+                      1 id (type: int)
+                    outputColumnNames: _col0, _col1, _col5
+                    input vertices:
+                      1 Map 4
+                    Statistics: Num rows: 9 Data size: 29 Basic stats: COMPLETE Column stats: NONE
+                    Filter Operator
+                      predicate: (_col1 = _col5) (type: boolean)
+                      Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                      Select Operator
+                        expressions: _col0 (type: decimal(10,0))
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 4 Data size: 12 Basic stats: COMPLETE Column stats: NONE
+                        File Output Operator
+                          compressed: false
+                          Statistics: Num rows: 8 Data size: 24 Basic stats: COMPLETE Column stats: NONE
+                          table:
+                              input format: org.apache.hadoop.mapred.TextInputFormat
+                              output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                              serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Local Work:
+              Map Reduce Local Work
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@agg_01
+PREHOOK: Input: default@agg_01@dim_shops_id=1
+PREHOOK: Input: default@agg_01@dim_shops_id=2
+PREHOOK: Input: default@agg_01@dim_shops_id=3
+PREHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@agg_01
+POSTHOOK: Input: default@agg_01@dim_shops_id=1
+POSTHOOK: Input: default@agg_01@dim_shops_id=2
+POSTHOOK: Input: default@agg_01@dim_shops_id=3
+POSTHOOK: Input: default@dim_shops
+#### A masked pattern was here ####
+1
+2
+3
+4
+5
+6


[37/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventResponse.java
index 0123e87..b988463 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NotificationEventResponse implements org.apache.thrift.TBase<NotificationEventResponse, NotificationEventResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NotificationEventResponse implements org.apache.thrift.TBase<NotificationEventResponse, NotificationEventResponse._Fields>, java.io.Serializable, Cloneable, Comparable<NotificationEventResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotificationEventResponse");
 
   private static final org.apache.thrift.protocol.TField EVENTS_FIELD_DESC = new org.apache.thrift.protocol.TField("events", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class NotificationEventResponse implements org.apache.thrift.TBase<Notifi
    */
   public NotificationEventResponse(NotificationEventResponse other) {
     if (other.isSetEvents()) {
-      List<NotificationEvent> __this__events = new ArrayList<NotificationEvent>();
+      List<NotificationEvent> __this__events = new ArrayList<NotificationEvent>(other.events.size());
       for (NotificationEvent other_element : other.events) {
         __this__events.add(new NotificationEvent(other_element));
       }
@@ -245,30 +249,30 @@ public class NotificationEventResponse implements org.apache.thrift.TBase<Notifi
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_events = true && (isSetEvents());
-    builder.append(present_events);
+    list.add(present_events);
     if (present_events)
-      builder.append(events);
+      list.add(events);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NotificationEventResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NotificationEventResponse typedOther = (NotificationEventResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetEvents()).compareTo(typedOther.isSetEvents());
+    lastComparison = Boolean.valueOf(isSetEvents()).compareTo(other.isSetEvents());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEvents()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.events, typedOther.events);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.events, other.events);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class NotificationEventResponse implements org.apache.thrift.TBase<Notifi
               {
                 org.apache.thrift.protocol.TList _list500 = iprot.readListBegin();
                 struct.events = new ArrayList<NotificationEvent>(_list500.size);
-                for (int _i501 = 0; _i501 < _list500.size; ++_i501)
+                NotificationEvent _elem501;
+                for (int _i502 = 0; _i502 < _list500.size; ++_i502)
                 {
-                  NotificationEvent _elem502; // optional
-                  _elem502 = new NotificationEvent();
-                  _elem502.read(iprot);
-                  struct.events.add(_elem502);
+                  _elem501 = new NotificationEvent();
+                  _elem501.read(iprot);
+                  struct.events.add(_elem501);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class NotificationEventResponse implements org.apache.thrift.TBase<Notifi
       {
         org.apache.thrift.protocol.TList _list505 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.events = new ArrayList<NotificationEvent>(_list505.size);
-        for (int _i506 = 0; _i506 < _list505.size; ++_i506)
+        NotificationEvent _elem506;
+        for (int _i507 = 0; _i507 < _list505.size; ++_i507)
         {
-          NotificationEvent _elem507; // optional
-          _elem507 = new NotificationEvent();
-          _elem507.read(iprot);
-          struct.events.add(_elem507);
+          _elem506 = new NotificationEvent();
+          _elem506.read(iprot);
+          struct.events.add(_elem506);
         }
       }
       struct.setEventsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnRequest.java
index 0d05378..c7990a6 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class OpenTxnRequest implements org.apache.thrift.TBase<OpenTxnRequest, OpenTxnRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class OpenTxnRequest implements org.apache.thrift.TBase<OpenTxnRequest, OpenTxnRequest._Fields>, java.io.Serializable, Cloneable, Comparable<OpenTxnRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("OpenTxnRequest");
 
   private static final org.apache.thrift.protocol.TField NUM_TXNS_FIELD_DESC = new org.apache.thrift.protocol.TField("num_txns", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -343,60 +347,60 @@ public class OpenTxnRequest implements org.apache.thrift.TBase<OpenTxnRequest, O
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_num_txns = true;
-    builder.append(present_num_txns);
+    list.add(present_num_txns);
     if (present_num_txns)
-      builder.append(num_txns);
+      list.add(num_txns);
 
     boolean present_user = true && (isSetUser());
-    builder.append(present_user);
+    list.add(present_user);
     if (present_user)
-      builder.append(user);
+      list.add(user);
 
     boolean present_hostname = true && (isSetHostname());
-    builder.append(present_hostname);
+    list.add(present_hostname);
     if (present_hostname)
-      builder.append(hostname);
+      list.add(hostname);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(OpenTxnRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    OpenTxnRequest typedOther = (OpenTxnRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetNum_txns()).compareTo(typedOther.isSetNum_txns());
+    lastComparison = Boolean.valueOf(isSetNum_txns()).compareTo(other.isSetNum_txns());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNum_txns()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.num_txns, typedOther.num_txns);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.num_txns, other.num_txns);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUser()).compareTo(typedOther.isSetUser());
+    lastComparison = Boolean.valueOf(isSetUser()).compareTo(other.isSetUser());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUser()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, typedOther.user);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, other.user);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(typedOther.isSetHostname());
+    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(other.isSetHostname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHostname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, typedOther.hostname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, other.hostname);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java
index f5efbe3..d90fdec 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsResponse, OpenTxnsResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsResponse, OpenTxnsResponse._Fields>, java.io.Serializable, Cloneable, Comparable<OpenTxnsResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("OpenTxnsResponse");
 
   private static final org.apache.thrift.protocol.TField TXN_IDS_FIELD_DESC = new org.apache.thrift.protocol.TField("txn_ids", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,10 +132,7 @@ public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsRespons
    */
   public OpenTxnsResponse(OpenTxnsResponse other) {
     if (other.isSetTxn_ids()) {
-      List<Long> __this__txn_ids = new ArrayList<Long>();
-      for (Long other_element : other.txn_ids) {
-        __this__txn_ids.add(other_element);
-      }
+      List<Long> __this__txn_ids = new ArrayList<Long>(other.txn_ids);
       this.txn_ids = __this__txn_ids;
     }
   }
@@ -245,30 +246,30 @@ public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsRespons
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txn_ids = true && (isSetTxn_ids());
-    builder.append(present_txn_ids);
+    list.add(present_txn_ids);
     if (present_txn_ids)
-      builder.append(txn_ids);
+      list.add(txn_ids);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(OpenTxnsResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    OpenTxnsResponse typedOther = (OpenTxnsResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetTxn_ids()).compareTo(typedOther.isSetTxn_ids());
+    lastComparison = Boolean.valueOf(isSetTxn_ids()).compareTo(other.isSetTxn_ids());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxn_ids()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_ids, typedOther.txn_ids);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_ids, other.txn_ids);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,11 +353,11 @@ public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsRespons
               {
                 org.apache.thrift.protocol.TList _list444 = iprot.readListBegin();
                 struct.txn_ids = new ArrayList<Long>(_list444.size);
-                for (int _i445 = 0; _i445 < _list444.size; ++_i445)
+                long _elem445;
+                for (int _i446 = 0; _i446 < _list444.size; ++_i446)
                 {
-                  long _elem446; // optional
-                  _elem446 = iprot.readI64();
-                  struct.txn_ids.add(_elem446);
+                  _elem445 = iprot.readI64();
+                  struct.txn_ids.add(_elem445);
                 }
                 iprot.readListEnd();
               }
@@ -422,11 +423,11 @@ public class OpenTxnsResponse implements org.apache.thrift.TBase<OpenTxnsRespons
       {
         org.apache.thrift.protocol.TList _list449 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I64, iprot.readI32());
         struct.txn_ids = new ArrayList<Long>(_list449.size);
-        for (int _i450 = 0; _i450 < _list449.size; ++_i450)
+        long _elem450;
+        for (int _i451 = 0; _i451 < _list449.size; ++_i451)
         {
-          long _elem451; // optional
-          _elem451 = iprot.readI64();
-          struct.txn_ids.add(_elem451);
+          _elem450 = iprot.readI64();
+          struct.txn_ids.add(_elem450);
         }
       }
       struct.setTxn_idsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Order.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Order.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Order.java
index 55d5174..7e906ae 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Order.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Order.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Order implements org.apache.thrift.TBase<Order, Order._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Order implements org.apache.thrift.TBase<Order, Order._Fields>, java.io.Serializable, Cloneable, Comparable<Order> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Order");
 
   private static final org.apache.thrift.protocol.TField COL_FIELD_DESC = new org.apache.thrift.protocol.TField("col", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -285,45 +289,45 @@ public class Order implements org.apache.thrift.TBase<Order, Order._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_col = true && (isSetCol());
-    builder.append(present_col);
+    list.add(present_col);
     if (present_col)
-      builder.append(col);
+      list.add(col);
 
     boolean present_order = true;
-    builder.append(present_order);
+    list.add(present_order);
     if (present_order)
-      builder.append(order);
+      list.add(order);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Order other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Order typedOther = (Order)other;
 
-    lastComparison = Boolean.valueOf(isSetCol()).compareTo(typedOther.isSetCol());
+    lastComparison = Boolean.valueOf(isSetCol()).compareTo(other.isSetCol());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCol()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.col, typedOther.col);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.col, other.col);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOrder()).compareTo(typedOther.isSetOrder());
+    lastComparison = Boolean.valueOf(isSetOrder()).compareTo(other.isSetOrder());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOrder()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.order, typedOther.order);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.order, other.order);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java
index 7d29d09..74a50ab 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Partition implements org.apache.thrift.TBase<Partition, Partition._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Partition implements org.apache.thrift.TBase<Partition, Partition._Fields>, java.io.Serializable, Cloneable, Comparable<Partition> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Partition");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -141,7 +145,7 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   private static final int __CREATETIME_ISSET_ID = 0;
   private static final int __LASTACCESSTIME_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PRIVILEGES};
+  private static final _Fields optionals[] = {_Fields.PRIVILEGES};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -182,14 +186,14 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   {
     this();
     this.values = values;
-    this.dbName = dbName;
-    this.tableName = tableName;
+    this.dbName = org.apache.hive.common.util.HiveStringUtils.intern(dbName);
+    this.tableName = org.apache.hive.common.util.HiveStringUtils.intern(tableName);
     this.createTime = createTime;
     setCreateTimeIsSet(true);
     this.lastAccessTime = lastAccessTime;
     setLastAccessTimeIsSet(true);
     this.sd = sd;
-    this.parameters = parameters;
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   /**
@@ -198,17 +202,14 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   public Partition(Partition other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetValues()) {
-      List<String> __this__values = new ArrayList<String>();
-      for (String other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<String> __this__values = new ArrayList<String>(other.values);
       this.values = __this__values;
     }
     if (other.isSetDbName()) {
-      this.dbName = other.dbName;
+      this.dbName = org.apache.hive.common.util.HiveStringUtils.intern(other.dbName);
     }
     if (other.isSetTableName()) {
-      this.tableName = other.tableName;
+      this.tableName = org.apache.hive.common.util.HiveStringUtils.intern(other.tableName);
     }
     this.createTime = other.createTime;
     this.lastAccessTime = other.lastAccessTime;
@@ -216,18 +217,7 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
       this.sd = new StorageDescriptor(other.sd);
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     if (other.isSetPrivileges()) {
@@ -296,7 +286,7 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   }
 
   public void setDbName(String dbName) {
-    this.dbName = dbName;
+    this.dbName = org.apache.hive.common.util.HiveStringUtils.intern(dbName);
   }
 
   public void unsetDbName() {
@@ -319,7 +309,7 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   }
 
   public void setTableName(String tableName) {
-    this.tableName = tableName;
+    this.tableName = org.apache.hive.common.util.HiveStringUtils.intern(tableName);
   }
 
   public void unsetTableName() {
@@ -420,7 +410,7 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
   }
 
   public void setParameters(Map<String,String> parameters) {
-    this.parameters = parameters;
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   public void unsetParameters() {
@@ -677,135 +667,135 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_lastAccessTime = true;
-    builder.append(present_lastAccessTime);
+    list.add(present_lastAccessTime);
     if (present_lastAccessTime)
-      builder.append(lastAccessTime);
+      list.add(lastAccessTime);
 
     boolean present_sd = true && (isSetSd());
-    builder.append(present_sd);
+    list.add(present_sd);
     if (present_sd)
-      builder.append(sd);
+      list.add(sd);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Partition other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Partition typedOther = (Partition)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(typedOther.isSetLastAccessTime());
+    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(other.isSetLastAccessTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastAccessTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, typedOther.lastAccessTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, other.lastAccessTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSd()).compareTo(typedOther.isSetSd());
+    lastComparison = Boolean.valueOf(isSetSd()).compareTo(other.isSetSd());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSd()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, typedOther.sd);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, other.sd);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -943,11 +933,11 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
               {
                 org.apache.thrift.protocol.TList _list208 = iprot.readListBegin();
                 struct.values = new ArrayList<String>(_list208.size);
-                for (int _i209 = 0; _i209 < _list208.size; ++_i209)
+                String _elem209;
+                for (int _i210 = 0; _i210 < _list208.size; ++_i210)
                 {
-                  String _elem210; // optional
-                  _elem210 = iprot.readString();
-                  struct.values.add(_elem210);
+                  _elem209 = iprot.readString();
+                  struct.values.add(_elem209);
                 }
                 iprot.readListEnd();
               }
@@ -1002,13 +992,13 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
               {
                 org.apache.thrift.protocol.TMap _map211 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map211.size);
-                for (int _i212 = 0; _i212 < _map211.size; ++_i212)
+                String _key212;
+                String _val213;
+                for (int _i214 = 0; _i214 < _map211.size; ++_i214)
                 {
-                  String _key213; // required
-                  String _val214; // required
-                  _key213 = iprot.readString();
-                  _val214 = iprot.readString();
-                  struct.parameters.put(_key213, _val214);
+                  _key212 = iprot.readString();
+                  _val213 = iprot.readString();
+                  struct.parameters.put(_key212, _val213);
                 }
                 iprot.readMapEnd();
               }
@@ -1182,11 +1172,11 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
         {
           org.apache.thrift.protocol.TList _list219 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.values = new ArrayList<String>(_list219.size);
-          for (int _i220 = 0; _i220 < _list219.size; ++_i220)
+          String _elem220;
+          for (int _i221 = 0; _i221 < _list219.size; ++_i221)
           {
-            String _elem221; // optional
-            _elem221 = iprot.readString();
-            struct.values.add(_elem221);
+            _elem220 = iprot.readString();
+            struct.values.add(_elem220);
           }
         }
         struct.setValuesIsSet(true);
@@ -1216,13 +1206,13 @@ public class Partition implements org.apache.thrift.TBase<Partition, Partition._
         {
           org.apache.thrift.protocol.TMap _map222 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map222.size);
-          for (int _i223 = 0; _i223 < _map222.size; ++_i223)
+          String _key223;
+          String _val224;
+          for (int _i225 = 0; _i225 < _map222.size; ++_i225)
           {
-            String _key224; // required
-            String _val225; // required
-            _key224 = iprot.readString();
-            _val225 = iprot.readString();
-            struct.parameters.put(_key224, _val225);
+            _key223 = iprot.readString();
+            _val224 = iprot.readString();
+            struct.parameters.put(_key223, _val224);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionEventType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionEventType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionEventType.java
index 6c75461..40bdb56 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionEventType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionEventType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionListComposingSpec.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionListComposingSpec.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionListComposingSpec.java
index bcd92b8..71d42f8 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionListComposingSpec.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionListComposingSpec.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionListComposingSpec implements org.apache.thrift.TBase<PartitionListComposingSpec, PartitionListComposingSpec._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionListComposingSpec implements org.apache.thrift.TBase<PartitionListComposingSpec, PartitionListComposingSpec._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionListComposingSpec> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionListComposingSpec");
 
   private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class PartitionListComposingSpec implements org.apache.thrift.TBase<Parti
    */
   public PartitionListComposingSpec(PartitionListComposingSpec other) {
     if (other.isSetPartitions()) {
-      List<Partition> __this__partitions = new ArrayList<Partition>();
+      List<Partition> __this__partitions = new ArrayList<Partition>(other.partitions.size());
       for (Partition other_element : other.partitions) {
         __this__partitions.add(new Partition(other_element));
       }
@@ -245,30 +249,30 @@ public class PartitionListComposingSpec implements org.apache.thrift.TBase<Parti
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partitions = true && (isSetPartitions());
-    builder.append(present_partitions);
+    list.add(present_partitions);
     if (present_partitions)
-      builder.append(partitions);
+      list.add(partitions);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionListComposingSpec other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionListComposingSpec typedOther = (PartitionListComposingSpec)other;
 
-    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(typedOther.isSetPartitions());
+    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, typedOther.partitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -348,12 +352,12 @@ public class PartitionListComposingSpec implements org.apache.thrift.TBase<Parti
               {
                 org.apache.thrift.protocol.TList _list252 = iprot.readListBegin();
                 struct.partitions = new ArrayList<Partition>(_list252.size);
-                for (int _i253 = 0; _i253 < _list252.size; ++_i253)
+                Partition _elem253;
+                for (int _i254 = 0; _i254 < _list252.size; ++_i254)
                 {
-                  Partition _elem254; // optional
-                  _elem254 = new Partition();
-                  _elem254.read(iprot);
-                  struct.partitions.add(_elem254);
+                  _elem253 = new Partition();
+                  _elem253.read(iprot);
+                  struct.partitions.add(_elem253);
                 }
                 iprot.readListEnd();
               }
@@ -428,12 +432,12 @@ public class PartitionListComposingSpec implements org.apache.thrift.TBase<Parti
         {
           org.apache.thrift.protocol.TList _list257 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.partitions = new ArrayList<Partition>(_list257.size);
-          for (int _i258 = 0; _i258 < _list257.size; ++_i258)
+          Partition _elem258;
+          for (int _i259 = 0; _i259 < _list257.size; ++_i259)
           {
-            Partition _elem259; // optional
-            _elem259 = new Partition();
-            _elem259.read(iprot);
-            struct.partitions.add(_elem259);
+            _elem258 = new Partition();
+            _elem258.read(iprot);
+            struct.partitions.add(_elem258);
           }
         }
         struct.setPartitionsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpec.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpec.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpec.java
index 06cc8fb..c5e2c34 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpec.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpec.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionSpec implements org.apache.thrift.TBase<PartitionSpec, PartitionSpec._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionSpec implements org.apache.thrift.TBase<PartitionSpec, PartitionSpec._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionSpec> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionSpec");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -123,7 +127,7 @@ public class PartitionSpec implements org.apache.thrift.TBase<PartitionSpec, Par
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.SHARED_SDPARTITION_SPEC,_Fields.PARTITION_LIST};
+  private static final _Fields optionals[] = {_Fields.SHARED_SDPARTITION_SPEC,_Fields.PARTITION_LIST};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -454,90 +458,90 @@ public class PartitionSpec implements org.apache.thrift.TBase<PartitionSpec, Par
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_rootPath = true && (isSetRootPath());
-    builder.append(present_rootPath);
+    list.add(present_rootPath);
     if (present_rootPath)
-      builder.append(rootPath);
+      list.add(rootPath);
 
     boolean present_sharedSDPartitionSpec = true && (isSetSharedSDPartitionSpec());
-    builder.append(present_sharedSDPartitionSpec);
+    list.add(present_sharedSDPartitionSpec);
     if (present_sharedSDPartitionSpec)
-      builder.append(sharedSDPartitionSpec);
+      list.add(sharedSDPartitionSpec);
 
     boolean present_partitionList = true && (isSetPartitionList());
-    builder.append(present_partitionList);
+    list.add(present_partitionList);
     if (present_partitionList)
-      builder.append(partitionList);
+      list.add(partitionList);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionSpec other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionSpec typedOther = (PartitionSpec)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRootPath()).compareTo(typedOther.isSetRootPath());
+    lastComparison = Boolean.valueOf(isSetRootPath()).compareTo(other.isSetRootPath());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRootPath()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rootPath, typedOther.rootPath);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rootPath, other.rootPath);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSharedSDPartitionSpec()).compareTo(typedOther.isSetSharedSDPartitionSpec());
+    lastComparison = Boolean.valueOf(isSetSharedSDPartitionSpec()).compareTo(other.isSetSharedSDPartitionSpec());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSharedSDPartitionSpec()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sharedSDPartitionSpec, typedOther.sharedSDPartitionSpec);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sharedSDPartitionSpec, other.sharedSDPartitionSpec);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionList()).compareTo(typedOther.isSetPartitionList());
+    lastComparison = Boolean.valueOf(isSetPartitionList()).compareTo(other.isSetPartitionList());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionList()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionList, typedOther.partitionList);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionList, other.partitionList);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpecWithSharedSD.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpecWithSharedSD.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpecWithSharedSD.java
index 18ab134..eebdd1d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpecWithSharedSD.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionSpecWithSharedSD.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<PartitionSpecWithSharedSD, PartitionSpecWithSharedSD._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<PartitionSpecWithSharedSD, PartitionSpecWithSharedSD._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionSpecWithSharedSD> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionSpecWithSharedSD");
 
   private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -137,7 +141,7 @@ public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<Partit
    */
   public PartitionSpecWithSharedSD(PartitionSpecWithSharedSD other) {
     if (other.isSetPartitions()) {
-      List<PartitionWithoutSD> __this__partitions = new ArrayList<PartitionWithoutSD>();
+      List<PartitionWithoutSD> __this__partitions = new ArrayList<PartitionWithoutSD>(other.partitions.size());
       for (PartitionWithoutSD other_element : other.partitions) {
         __this__partitions.add(new PartitionWithoutSD(other_element));
       }
@@ -303,45 +307,45 @@ public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<Partit
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partitions = true && (isSetPartitions());
-    builder.append(present_partitions);
+    list.add(present_partitions);
     if (present_partitions)
-      builder.append(partitions);
+      list.add(partitions);
 
     boolean present_sd = true && (isSetSd());
-    builder.append(present_sd);
+    list.add(present_sd);
     if (present_sd)
-      builder.append(sd);
+      list.add(sd);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionSpecWithSharedSD other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionSpecWithSharedSD typedOther = (PartitionSpecWithSharedSD)other;
 
-    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(typedOther.isSetPartitions());
+    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, typedOther.partitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSd()).compareTo(typedOther.isSetSd());
+    lastComparison = Boolean.valueOf(isSetSd()).compareTo(other.isSetSd());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSd()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, typedOther.sd);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, other.sd);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -432,12 +436,12 @@ public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<Partit
               {
                 org.apache.thrift.protocol.TList _list244 = iprot.readListBegin();
                 struct.partitions = new ArrayList<PartitionWithoutSD>(_list244.size);
-                for (int _i245 = 0; _i245 < _list244.size; ++_i245)
+                PartitionWithoutSD _elem245;
+                for (int _i246 = 0; _i246 < _list244.size; ++_i246)
                 {
-                  PartitionWithoutSD _elem246; // optional
-                  _elem246 = new PartitionWithoutSD();
-                  _elem246.read(iprot);
-                  struct.partitions.add(_elem246);
+                  _elem245 = new PartitionWithoutSD();
+                  _elem245.read(iprot);
+                  struct.partitions.add(_elem245);
                 }
                 iprot.readListEnd();
               }
@@ -532,12 +536,12 @@ public class PartitionSpecWithSharedSD implements org.apache.thrift.TBase<Partit
         {
           org.apache.thrift.protocol.TList _list249 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.partitions = new ArrayList<PartitionWithoutSD>(_list249.size);
-          for (int _i250 = 0; _i250 < _list249.size; ++_i250)
+          PartitionWithoutSD _elem250;
+          for (int _i251 = 0; _i251 < _list249.size; ++_i251)
           {
-            PartitionWithoutSD _elem251; // optional
-            _elem251 = new PartitionWithoutSD();
-            _elem251.read(iprot);
-            struct.partitions.add(_elem251);
+            _elem250 = new PartitionWithoutSD();
+            _elem250.read(iprot);
+            struct.partitions.add(_elem250);
           }
         }
         struct.setPartitionsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionWithoutSD.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionWithoutSD.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionWithoutSD.java
index 193d9e9..d69547d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionWithoutSD.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionWithoutSD.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWithoutSD, PartitionWithoutSD._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWithoutSD, PartitionWithoutSD._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionWithoutSD> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionWithoutSD");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -131,7 +135,7 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
   private static final int __CREATETIME_ISSET_ID = 0;
   private static final int __LASTACCESSTIME_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PRIVILEGES};
+  private static final _Fields optionals[] = {_Fields.PRIVILEGES};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -180,10 +184,7 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
   public PartitionWithoutSD(PartitionWithoutSD other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetValues()) {
-      List<String> __this__values = new ArrayList<String>();
-      for (String other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<String> __this__values = new ArrayList<String>(other.values);
       this.values = __this__values;
     }
     this.createTime = other.createTime;
@@ -192,18 +193,7 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
       this.relativePath = other.relativePath;
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     if (other.isSetPrivileges()) {
@@ -561,105 +551,105 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_lastAccessTime = true;
-    builder.append(present_lastAccessTime);
+    list.add(present_lastAccessTime);
     if (present_lastAccessTime)
-      builder.append(lastAccessTime);
+      list.add(lastAccessTime);
 
     boolean present_relativePath = true && (isSetRelativePath());
-    builder.append(present_relativePath);
+    list.add(present_relativePath);
     if (present_relativePath)
-      builder.append(relativePath);
+      list.add(relativePath);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionWithoutSD other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionWithoutSD typedOther = (PartitionWithoutSD)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(typedOther.isSetLastAccessTime());
+    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(other.isSetLastAccessTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastAccessTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, typedOther.lastAccessTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, other.lastAccessTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRelativePath()).compareTo(typedOther.isSetRelativePath());
+    lastComparison = Boolean.valueOf(isSetRelativePath()).compareTo(other.isSetRelativePath());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRelativePath()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.relativePath, typedOther.relativePath);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.relativePath, other.relativePath);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -778,11 +768,11 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
               {
                 org.apache.thrift.protocol.TList _list226 = iprot.readListBegin();
                 struct.values = new ArrayList<String>(_list226.size);
-                for (int _i227 = 0; _i227 < _list226.size; ++_i227)
+                String _elem227;
+                for (int _i228 = 0; _i228 < _list226.size; ++_i228)
                 {
-                  String _elem228; // optional
-                  _elem228 = iprot.readString();
-                  struct.values.add(_elem228);
+                  _elem227 = iprot.readString();
+                  struct.values.add(_elem227);
                 }
                 iprot.readListEnd();
               }
@@ -820,13 +810,13 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
               {
                 org.apache.thrift.protocol.TMap _map229 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map229.size);
-                for (int _i230 = 0; _i230 < _map229.size; ++_i230)
+                String _key230;
+                String _val231;
+                for (int _i232 = 0; _i232 < _map229.size; ++_i232)
                 {
-                  String _key231; // required
-                  String _val232; // required
-                  _key231 = iprot.readString();
-                  _val232 = iprot.readString();
-                  struct.parameters.put(_key231, _val232);
+                  _key230 = iprot.readString();
+                  _val231 = iprot.readString();
+                  struct.parameters.put(_key230, _val231);
                 }
                 iprot.readMapEnd();
               }
@@ -978,11 +968,11 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
         {
           org.apache.thrift.protocol.TList _list237 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.values = new ArrayList<String>(_list237.size);
-          for (int _i238 = 0; _i238 < _list237.size; ++_i238)
+          String _elem238;
+          for (int _i239 = 0; _i239 < _list237.size; ++_i239)
           {
-            String _elem239; // optional
-            _elem239 = iprot.readString();
-            struct.values.add(_elem239);
+            _elem238 = iprot.readString();
+            struct.values.add(_elem238);
           }
         }
         struct.setValuesIsSet(true);
@@ -1003,13 +993,13 @@ public class PartitionWithoutSD implements org.apache.thrift.TBase<PartitionWith
         {
           org.apache.thrift.protocol.TMap _map240 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map240.size);
-          for (int _i241 = 0; _i241 < _map240.size; ++_i241)
+          String _key241;
+          String _val242;
+          for (int _i243 = 0; _i243 < _map240.size; ++_i243)
           {
-            String _key242; // required
-            String _val243; // required
-            _key242 = iprot.readString();
-            _val243 = iprot.readString();
-            struct.parameters.put(_key242, _val243);
+            _key241 = iprot.readString();
+            _val242 = iprot.readString();
+            struct.parameters.put(_key241, _val242);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprRequest.java
index c6fa8a2..7fd485e 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionsByExprRequest implements org.apache.thrift.TBase<PartitionsByExprRequest, PartitionsByExprRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionsByExprRequest implements org.apache.thrift.TBase<PartitionsByExprRequest, PartitionsByExprRequest._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionsByExprRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionsByExprRequest");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -125,7 +129,7 @@ public class PartitionsByExprRequest implements org.apache.thrift.TBase<Partitio
   // isset id assignments
   private static final int __MAXPARTS_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.DEFAULT_PARTITION_NAME,_Fields.MAX_PARTS};
+  private static final _Fields optionals[] = {_Fields.DEFAULT_PARTITION_NAME,_Fields.MAX_PARTS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -156,7 +160,7 @@ public class PartitionsByExprRequest implements org.apache.thrift.TBase<Partitio
     this();
     this.dbName = dbName;
     this.tblName = tblName;
-    this.expr = expr;
+    this.expr = org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   /**
@@ -172,7 +176,6 @@ public class PartitionsByExprRequest implements org.apache.thrift.TBase<Partitio
     }
     if (other.isSetExpr()) {
       this.expr = org.apache.thrift.TBaseHelper.copyBinary(other.expr);
-;
     }
     if (other.isSetDefaultPartitionName()) {
       this.defaultPartitionName = other.defaultPartitionName;
@@ -246,15 +249,15 @@ public class PartitionsByExprRequest implements org.apache.thrift.TBase<Partitio
   }
 
   public ByteBuffer bufferForExpr() {
-    return expr;
+    return org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   public void setExpr(byte[] expr) {
-    setExpr(expr == null ? (ByteBuffer)null : ByteBuffer.wrap(expr));
+    this.expr = expr == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(expr, expr.length));
   }
 
   public void setExpr(ByteBuffer expr) {
-    this.expr = expr;
+    this.expr = org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   public void unsetExpr() {
@@ -467,90 +470,90 @@ public class PartitionsByExprRequest implements org.apache.thrift.TBase<Partitio
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tblName = true && (isSetTblName());
-    builder.append(present_tblName);
+    list.add(present_tblName);
     if (present_tblName)
-      builder.append(tblName);
+      list.add(tblName);
 
     boolean present_expr = true && (isSetExpr());
-    builder.append(present_expr);
+    list.add(present_expr);
     if (present_expr)
-      builder.append(expr);
+      list.add(expr);
 
     boolean present_defaultPartitionName = true && (isSetDefaultPartitionName());
-    builder.append(present_defaultPartitionName);
+    list.add(present_defaultPartitionName);
     if (present_defaultPartitionName)
-      builder.append(defaultPartitionName);
+      list.add(defaultPartitionName);
 
     boolean present_maxParts = true && (isSetMaxParts());
-    builder.append(present_maxParts);
+    list.add(present_maxParts);
     if (present_maxParts)
-      builder.append(maxParts);
+      list.add(maxParts);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionsByExprRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionsByExprRequest typedOther = (PartitionsByExprRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(typedOther.isSetTblName());
+    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(other.isSetTblName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTblName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, typedOther.tblName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, other.tblName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetExpr()).compareTo(typedOther.isSetExpr());
+    lastComparison = Boolean.valueOf(isSetExpr()).compareTo(other.isSetExpr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetExpr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.expr, typedOther.expr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.expr, other.expr);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDefaultPartitionName()).compareTo(typedOther.isSetDefaultPartitionName());
+    lastComparison = Boolean.valueOf(isSetDefaultPartitionName()).compareTo(other.isSetDefaultPartitionName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDefaultPartitionName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.defaultPartitionName, typedOther.defaultPartitionName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.defaultPartitionName, other.defaultPartitionName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMaxParts()).compareTo(typedOther.isSetMaxParts());
+    lastComparison = Boolean.valueOf(isSetMaxParts()).compareTo(other.isSetMaxParts());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxParts()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxParts, typedOther.maxParts);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxParts, other.maxParts);
       if (lastComparison != 0) {
         return lastComparison;
       }


[20/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/spark_vectorized_dynamic_partition_pruning.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/spark_vectorized_dynamic_partition_pruning.q.out b/ql/src/test/results/clientpositive/spark/spark_vectorized_dynamic_partition_pruning.q.out
new file mode 100644
index 0000000..9cab06c
--- /dev/null
+++ b/ql/src/test/results/clientpositive/spark/spark_vectorized_dynamic_partition_pruning.q.out
@@ -0,0 +1,5822 @@
+PREHOOK: query: select distinct ds from srcpart
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: select distinct ds from srcpart
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+2008-04-08
+2008-04-09
+PREHOOK: query: select distinct hr from srcpart
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: select distinct hr from srcpart
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+11
+12
+PREHOOK: query: EXPLAIN create table srcpart_date as select ds as ds, ds as `date` from srcpart group by ds
+PREHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: query: EXPLAIN create table srcpart_date as select ds as ds, ds as `date` from srcpart group by ds
+POSTHOOK: type: CREATETABLE_AS_SELECT
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+  Stage-3 depends on stages: Stage-0
+  Stage-2 depends on stages: Stage-3
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (GROUP, 2)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Select Operator
+                    expressions: ds (type: string)
+                    outputColumnNames: _col0
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    Group By Operator
+                      keys: _col0 (type: string)
+                      mode: hash
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                      Reduce Output Operator
+                        key expressions: _col0 (type: string)
+                        sort order: +
+                        Map-reduce partition columns: _col0 (type: string)
+                        Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                Select Operator
+                  expressions: _col0 (type: string), _col0 (type: string)
+                  outputColumnNames: _col0, _col1
+                  Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                  File Output Operator
+                    compressed: false
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    table:
+                        input format: org.apache.hadoop.mapred.TextInputFormat
+                        output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+                        name: default.srcpart_date
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Move Operator
+      files:
+          hdfs directory: true
+#### A masked pattern was here ####
+
+  Stage: Stage-3
+      Create Table Operator:
+        Create Table
+          columns: ds string, date string
+          input format: org.apache.hadoop.mapred.TextInputFormat
+          output format: org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
+          serde name: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+          name: default.srcpart_date
+
+  Stage: Stage-2
+    Stats-Aggr Operator
+
+PREHOOK: query: create table srcpart_date stored as orc as select ds as ds, ds as `date` from srcpart group by ds
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_date
+POSTHOOK: query: create table srcpart_date stored as orc as select ds as ds, ds as `date` from srcpart group by ds
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_date
+PREHOOK: query: create table srcpart_hour stored as orc as select hr as hr, hr as hour from srcpart group by hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_hour
+POSTHOOK: query: create table srcpart_hour stored as orc as select hr as hr, hr as hour from srcpart group by hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_hour
+PREHOOK: query: create table srcpart_date_hour stored as orc as select ds as ds, ds as `date`, hr as hr, hr as hour from srcpart group by ds, hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_date_hour
+POSTHOOK: query: create table srcpart_date_hour stored as orc as select ds as ds, ds as `date`, hr as hr, hr as hour from srcpart group by ds, hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_date_hour
+PREHOOK: query: create table srcpart_double_hour stored as orc as select (hr*2) as hr, hr as hour from srcpart group by hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_double_hour
+POSTHOOK: query: create table srcpart_double_hour stored as orc as select (hr*2) as hr, hr as hour from srcpart group by hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_double_hour
+PREHOOK: query: -- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+PREHOOK: type: QUERY
+POSTHOOK: query: -- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+            Execution mode: vectorized
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+1000
+PREHOOK: query: select count(*) from srcpart where ds = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+#### A masked pattern was here ####
+1000
+PREHOOK: query: -- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 7 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+            Execution mode: vectorized
+        Map 8 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 344 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: hr
+                          Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 5 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Map 6 (PARTITION-LEVEL SORT, 2), Reducer 2 (PARTITION-LEVEL SORT, 2)
+        Reducer 4 <- Reducer 3 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: hr (type: string)
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 344 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: string)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: string)
+                      Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                outputColumnNames: _col3
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col3 (type: string)
+                  sort order: +
+                  Map-reduce partition columns: _col3 (type: string)
+                  Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+        Reducer 3 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 _col3 (type: string)
+                  1 hr (type: string)
+                Statistics: Num rows: 2420 Data size: 25709 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 4 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+PREHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+POSTHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 5 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Map 6 (PARTITION-LEVEL SORT, 2), Reducer 2 (PARTITION-LEVEL SORT, 2)
+        Reducer 4 <- Reducer 3 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (ds is not null and hr is not null) (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: hr (type: string)
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 344 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: string)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: string)
+                      Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                outputColumnNames: _col3
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col3 (type: string)
+                  sort order: +
+                  Map-reduce partition columns: _col3 (type: string)
+                  Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+        Reducer 3 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 _col3 (type: string)
+                  1 hr (type: string)
+                Statistics: Num rows: 2420 Data size: 25709 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 4 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+PREHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+POSTHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: select count(*) from srcpart where hr = 11 and ds = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where hr = 11 and ds = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+500
+PREHOOK: query: -- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 1440 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 1440 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: hr
+                          Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string), hr (type: string)
+                    sort order: ++
+                    Map-reduce partition columns: ds (type: string), hr (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 1440 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string), hr (type: string)
+                      sort order: ++
+                      Map-reduce partition columns: ds (type: string), hr (type: string)
+                      Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string), hr (type: string)
+                  1 ds (type: string), hr (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (ds is not null and hr is not null) (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string), hr (type: string)
+                    sort order: ++
+                    Map-reduce partition columns: ds (type: string), hr (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 1440 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string), hr (type: string)
+                      sort order: ++
+                      Map-reduce partition columns: ds (type: string), hr (type: string)
+                      Statistics: Num rows: 1 Data size: 360 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string), hr (type: string)
+                  1 ds (type: string), hr (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: select count(*) from srcpart where ds = '2008-04-08' and hr = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = '2008-04-08' and hr = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+500
+PREHOOK: query: -- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+PREHOOK: type: QUERY
+POSTHOOK: query: -- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+            Execution mode: vectorized
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+0
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 376 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+            Execution mode: vectorized
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+0
+PREHOOK: query: select count(*) from srcpart where ds = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+#### A masked pattern was here ####
+0
+PREHOOK: query: -- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: double)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: UDFToDouble(hr)
+                          Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: UDFToDouble(hr) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: UDFToDouble(hr) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(hr) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(hr) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 UDFToDouble(hr) (type: double)
+                  1 UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: double)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: double)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: (hr * 2)
+                          Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (hr * 2) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr * 2) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: (hr * 2) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: (hr * 2) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: double)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: double)
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 (hr * 2) (type: double)
+                  1 hr (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: UDFToDouble(hr) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: UDFToDouble(hr) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(hr) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(hr) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 UDFToDouble(hr) (type: double)
+                  1 UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (hr * 2) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr * 2) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: (hr * 2) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: (hr * 2) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 188 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: double)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: double)
+                      Statistics: Num rows: 1 Data size: 94 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 (hr * 2) (type: double)
+                  1 hr (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+            Execution mode: vectorized
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: select count(*) from srcpart where hr = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where hr = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A ma

<TRUNCATED>

[15/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService.cpp b/service/src/gen/thrift/gen-cpp/TCLIService.cpp
index 209ce63..7dae2f8 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService.cpp
+++ b/service/src/gen/thrift/gen-cpp/TCLIService.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -8,6 +8,11 @@
 
 namespace apache { namespace hive { namespace service { namespace cli { namespace thrift {
 
+
+TCLIService_OpenSession_args::~TCLIService_OpenSession_args() throw() {
+}
+
+
 uint32_t TCLIService_OpenSession_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -50,6 +55,7 @@ uint32_t TCLIService_OpenSession_args::read(::apache::thrift::protocol::TProtoco
 
 uint32_t TCLIService_OpenSession_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_OpenSession_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -58,11 +64,18 @@ uint32_t TCLIService_OpenSession_args::write(::apache::thrift::protocol::TProtoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_OpenSession_pargs::~TCLIService_OpenSession_pargs() throw() {
+}
+
+
 uint32_t TCLIService_OpenSession_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_OpenSession_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -71,9 +84,15 @@ uint32_t TCLIService_OpenSession_pargs::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_OpenSession_result::~TCLIService_OpenSession_result() throw() {
+}
+
+
 uint32_t TCLIService_OpenSession_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -130,6 +149,11 @@ uint32_t TCLIService_OpenSession_result::write(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_OpenSession_presult::~TCLIService_OpenSession_presult() throw() {
+}
+
+
 uint32_t TCLIService_OpenSession_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -170,6 +194,11 @@ uint32_t TCLIService_OpenSession_presult::read(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_CloseSession_args::~TCLIService_CloseSession_args() throw() {
+}
+
+
 uint32_t TCLIService_CloseSession_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -212,6 +241,7 @@ uint32_t TCLIService_CloseSession_args::read(::apache::thrift::protocol::TProtoc
 
 uint32_t TCLIService_CloseSession_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CloseSession_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -220,11 +250,18 @@ uint32_t TCLIService_CloseSession_args::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CloseSession_pargs::~TCLIService_CloseSession_pargs() throw() {
+}
+
+
 uint32_t TCLIService_CloseSession_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CloseSession_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -233,9 +270,15 @@ uint32_t TCLIService_CloseSession_pargs::write(::apache::thrift::protocol::TProt
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CloseSession_result::~TCLIService_CloseSession_result() throw() {
+}
+
+
 uint32_t TCLIService_CloseSession_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -292,6 +335,11 @@ uint32_t TCLIService_CloseSession_result::write(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_CloseSession_presult::~TCLIService_CloseSession_presult() throw() {
+}
+
+
 uint32_t TCLIService_CloseSession_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -332,6 +380,11 @@ uint32_t TCLIService_CloseSession_presult::read(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_GetInfo_args::~TCLIService_GetInfo_args() throw() {
+}
+
+
 uint32_t TCLIService_GetInfo_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -374,6 +427,7 @@ uint32_t TCLIService_GetInfo_args::read(::apache::thrift::protocol::TProtocol* i
 
 uint32_t TCLIService_GetInfo_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetInfo_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -382,11 +436,18 @@ uint32_t TCLIService_GetInfo_args::write(::apache::thrift::protocol::TProtocol*
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetInfo_pargs::~TCLIService_GetInfo_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetInfo_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetInfo_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -395,9 +456,15 @@ uint32_t TCLIService_GetInfo_pargs::write(::apache::thrift::protocol::TProtocol*
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetInfo_result::~TCLIService_GetInfo_result() throw() {
+}
+
+
 uint32_t TCLIService_GetInfo_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -454,6 +521,11 @@ uint32_t TCLIService_GetInfo_result::write(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+TCLIService_GetInfo_presult::~TCLIService_GetInfo_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetInfo_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -494,6 +566,11 @@ uint32_t TCLIService_GetInfo_presult::read(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+TCLIService_ExecuteStatement_args::~TCLIService_ExecuteStatement_args() throw() {
+}
+
+
 uint32_t TCLIService_ExecuteStatement_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -536,6 +613,7 @@ uint32_t TCLIService_ExecuteStatement_args::read(::apache::thrift::protocol::TPr
 
 uint32_t TCLIService_ExecuteStatement_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_ExecuteStatement_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -544,11 +622,18 @@ uint32_t TCLIService_ExecuteStatement_args::write(::apache::thrift::protocol::TP
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_ExecuteStatement_pargs::~TCLIService_ExecuteStatement_pargs() throw() {
+}
+
+
 uint32_t TCLIService_ExecuteStatement_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_ExecuteStatement_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -557,9 +642,15 @@ uint32_t TCLIService_ExecuteStatement_pargs::write(::apache::thrift::protocol::T
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_ExecuteStatement_result::~TCLIService_ExecuteStatement_result() throw() {
+}
+
+
 uint32_t TCLIService_ExecuteStatement_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -616,6 +707,11 @@ uint32_t TCLIService_ExecuteStatement_result::write(::apache::thrift::protocol::
   return xfer;
 }
 
+
+TCLIService_ExecuteStatement_presult::~TCLIService_ExecuteStatement_presult() throw() {
+}
+
+
 uint32_t TCLIService_ExecuteStatement_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -656,6 +752,11 @@ uint32_t TCLIService_ExecuteStatement_presult::read(::apache::thrift::protocol::
   return xfer;
 }
 
+
+TCLIService_GetTypeInfo_args::~TCLIService_GetTypeInfo_args() throw() {
+}
+
+
 uint32_t TCLIService_GetTypeInfo_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -698,6 +799,7 @@ uint32_t TCLIService_GetTypeInfo_args::read(::apache::thrift::protocol::TProtoco
 
 uint32_t TCLIService_GetTypeInfo_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTypeInfo_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -706,11 +808,18 @@ uint32_t TCLIService_GetTypeInfo_args::write(::apache::thrift::protocol::TProtoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTypeInfo_pargs::~TCLIService_GetTypeInfo_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetTypeInfo_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTypeInfo_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -719,9 +828,15 @@ uint32_t TCLIService_GetTypeInfo_pargs::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTypeInfo_result::~TCLIService_GetTypeInfo_result() throw() {
+}
+
+
 uint32_t TCLIService_GetTypeInfo_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -778,6 +893,11 @@ uint32_t TCLIService_GetTypeInfo_result::write(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_GetTypeInfo_presult::~TCLIService_GetTypeInfo_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetTypeInfo_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -818,6 +938,11 @@ uint32_t TCLIService_GetTypeInfo_presult::read(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_GetCatalogs_args::~TCLIService_GetCatalogs_args() throw() {
+}
+
+
 uint32_t TCLIService_GetCatalogs_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -860,6 +985,7 @@ uint32_t TCLIService_GetCatalogs_args::read(::apache::thrift::protocol::TProtoco
 
 uint32_t TCLIService_GetCatalogs_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetCatalogs_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -868,11 +994,18 @@ uint32_t TCLIService_GetCatalogs_args::write(::apache::thrift::protocol::TProtoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetCatalogs_pargs::~TCLIService_GetCatalogs_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetCatalogs_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetCatalogs_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -881,9 +1014,15 @@ uint32_t TCLIService_GetCatalogs_pargs::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetCatalogs_result::~TCLIService_GetCatalogs_result() throw() {
+}
+
+
 uint32_t TCLIService_GetCatalogs_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -940,6 +1079,11 @@ uint32_t TCLIService_GetCatalogs_result::write(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_GetCatalogs_presult::~TCLIService_GetCatalogs_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetCatalogs_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -980,6 +1124,11 @@ uint32_t TCLIService_GetCatalogs_presult::read(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+TCLIService_GetSchemas_args::~TCLIService_GetSchemas_args() throw() {
+}
+
+
 uint32_t TCLIService_GetSchemas_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1022,6 +1171,7 @@ uint32_t TCLIService_GetSchemas_args::read(::apache::thrift::protocol::TProtocol
 
 uint32_t TCLIService_GetSchemas_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetSchemas_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1030,11 +1180,18 @@ uint32_t TCLIService_GetSchemas_args::write(::apache::thrift::protocol::TProtoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetSchemas_pargs::~TCLIService_GetSchemas_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetSchemas_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetSchemas_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1043,9 +1200,15 @@ uint32_t TCLIService_GetSchemas_pargs::write(::apache::thrift::protocol::TProtoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetSchemas_result::~TCLIService_GetSchemas_result() throw() {
+}
+
+
 uint32_t TCLIService_GetSchemas_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1102,6 +1265,11 @@ uint32_t TCLIService_GetSchemas_result::write(::apache::thrift::protocol::TProto
   return xfer;
 }
 
+
+TCLIService_GetSchemas_presult::~TCLIService_GetSchemas_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetSchemas_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1142,6 +1310,11 @@ uint32_t TCLIService_GetSchemas_presult::read(::apache::thrift::protocol::TProto
   return xfer;
 }
 
+
+TCLIService_GetTables_args::~TCLIService_GetTables_args() throw() {
+}
+
+
 uint32_t TCLIService_GetTables_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1184,6 +1357,7 @@ uint32_t TCLIService_GetTables_args::read(::apache::thrift::protocol::TProtocol*
 
 uint32_t TCLIService_GetTables_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTables_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1192,11 +1366,18 @@ uint32_t TCLIService_GetTables_args::write(::apache::thrift::protocol::TProtocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTables_pargs::~TCLIService_GetTables_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetTables_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTables_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1205,9 +1386,15 @@ uint32_t TCLIService_GetTables_pargs::write(::apache::thrift::protocol::TProtoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTables_result::~TCLIService_GetTables_result() throw() {
+}
+
+
 uint32_t TCLIService_GetTables_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1264,6 +1451,11 @@ uint32_t TCLIService_GetTables_result::write(::apache::thrift::protocol::TProtoc
   return xfer;
 }
 
+
+TCLIService_GetTables_presult::~TCLIService_GetTables_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetTables_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1304,6 +1496,11 @@ uint32_t TCLIService_GetTables_presult::read(::apache::thrift::protocol::TProtoc
   return xfer;
 }
 
+
+TCLIService_GetTableTypes_args::~TCLIService_GetTableTypes_args() throw() {
+}
+
+
 uint32_t TCLIService_GetTableTypes_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1346,6 +1543,7 @@ uint32_t TCLIService_GetTableTypes_args::read(::apache::thrift::protocol::TProto
 
 uint32_t TCLIService_GetTableTypes_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTableTypes_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1354,11 +1552,18 @@ uint32_t TCLIService_GetTableTypes_args::write(::apache::thrift::protocol::TProt
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTableTypes_pargs::~TCLIService_GetTableTypes_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetTableTypes_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetTableTypes_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1367,9 +1572,15 @@ uint32_t TCLIService_GetTableTypes_pargs::write(::apache::thrift::protocol::TPro
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetTableTypes_result::~TCLIService_GetTableTypes_result() throw() {
+}
+
+
 uint32_t TCLIService_GetTableTypes_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1426,6 +1637,11 @@ uint32_t TCLIService_GetTableTypes_result::write(::apache::thrift::protocol::TPr
   return xfer;
 }
 
+
+TCLIService_GetTableTypes_presult::~TCLIService_GetTableTypes_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetTableTypes_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1466,6 +1682,11 @@ uint32_t TCLIService_GetTableTypes_presult::read(::apache::thrift::protocol::TPr
   return xfer;
 }
 
+
+TCLIService_GetColumns_args::~TCLIService_GetColumns_args() throw() {
+}
+
+
 uint32_t TCLIService_GetColumns_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1508,6 +1729,7 @@ uint32_t TCLIService_GetColumns_args::read(::apache::thrift::protocol::TProtocol
 
 uint32_t TCLIService_GetColumns_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetColumns_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1516,11 +1738,18 @@ uint32_t TCLIService_GetColumns_args::write(::apache::thrift::protocol::TProtoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetColumns_pargs::~TCLIService_GetColumns_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetColumns_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetColumns_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1529,9 +1758,15 @@ uint32_t TCLIService_GetColumns_pargs::write(::apache::thrift::protocol::TProtoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetColumns_result::~TCLIService_GetColumns_result() throw() {
+}
+
+
 uint32_t TCLIService_GetColumns_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1588,6 +1823,11 @@ uint32_t TCLIService_GetColumns_result::write(::apache::thrift::protocol::TProto
   return xfer;
 }
 
+
+TCLIService_GetColumns_presult::~TCLIService_GetColumns_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetColumns_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1628,6 +1868,11 @@ uint32_t TCLIService_GetColumns_presult::read(::apache::thrift::protocol::TProto
   return xfer;
 }
 
+
+TCLIService_GetFunctions_args::~TCLIService_GetFunctions_args() throw() {
+}
+
+
 uint32_t TCLIService_GetFunctions_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1670,6 +1915,7 @@ uint32_t TCLIService_GetFunctions_args::read(::apache::thrift::protocol::TProtoc
 
 uint32_t TCLIService_GetFunctions_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetFunctions_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1678,11 +1924,18 @@ uint32_t TCLIService_GetFunctions_args::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetFunctions_pargs::~TCLIService_GetFunctions_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetFunctions_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetFunctions_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1691,9 +1944,15 @@ uint32_t TCLIService_GetFunctions_pargs::write(::apache::thrift::protocol::TProt
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetFunctions_result::~TCLIService_GetFunctions_result() throw() {
+}
+
+
 uint32_t TCLIService_GetFunctions_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1750,6 +2009,11 @@ uint32_t TCLIService_GetFunctions_result::write(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_GetFunctions_presult::~TCLIService_GetFunctions_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetFunctions_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1790,6 +2054,11 @@ uint32_t TCLIService_GetFunctions_presult::read(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_GetOperationStatus_args::~TCLIService_GetOperationStatus_args() throw() {
+}
+
+
 uint32_t TCLIService_GetOperationStatus_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1832,6 +2101,7 @@ uint32_t TCLIService_GetOperationStatus_args::read(::apache::thrift::protocol::T
 
 uint32_t TCLIService_GetOperationStatus_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetOperationStatus_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1840,11 +2110,18 @@ uint32_t TCLIService_GetOperationStatus_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetOperationStatus_pargs::~TCLIService_GetOperationStatus_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetOperationStatus_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetOperationStatus_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1853,9 +2130,15 @@ uint32_t TCLIService_GetOperationStatus_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetOperationStatus_result::~TCLIService_GetOperationStatus_result() throw() {
+}
+
+
 uint32_t TCLIService_GetOperationStatus_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1912,6 +2195,11 @@ uint32_t TCLIService_GetOperationStatus_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+TCLIService_GetOperationStatus_presult::~TCLIService_GetOperationStatus_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetOperationStatus_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1952,6 +2240,11 @@ uint32_t TCLIService_GetOperationStatus_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+TCLIService_CancelOperation_args::~TCLIService_CancelOperation_args() throw() {
+}
+
+
 uint32_t TCLIService_CancelOperation_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1994,6 +2287,7 @@ uint32_t TCLIService_CancelOperation_args::read(::apache::thrift::protocol::TPro
 
 uint32_t TCLIService_CancelOperation_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CancelOperation_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2002,11 +2296,18 @@ uint32_t TCLIService_CancelOperation_args::write(::apache::thrift::protocol::TPr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CancelOperation_pargs::~TCLIService_CancelOperation_pargs() throw() {
+}
+
+
 uint32_t TCLIService_CancelOperation_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CancelOperation_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2015,9 +2316,15 @@ uint32_t TCLIService_CancelOperation_pargs::write(::apache::thrift::protocol::TP
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CancelOperation_result::~TCLIService_CancelOperation_result() throw() {
+}
+
+
 uint32_t TCLIService_CancelOperation_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2074,6 +2381,11 @@ uint32_t TCLIService_CancelOperation_result::write(::apache::thrift::protocol::T
   return xfer;
 }
 
+
+TCLIService_CancelOperation_presult::~TCLIService_CancelOperation_presult() throw() {
+}
+
+
 uint32_t TCLIService_CancelOperation_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2114,6 +2426,11 @@ uint32_t TCLIService_CancelOperation_presult::read(::apache::thrift::protocol::T
   return xfer;
 }
 
+
+TCLIService_CloseOperation_args::~TCLIService_CloseOperation_args() throw() {
+}
+
+
 uint32_t TCLIService_CloseOperation_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2156,6 +2473,7 @@ uint32_t TCLIService_CloseOperation_args::read(::apache::thrift::protocol::TProt
 
 uint32_t TCLIService_CloseOperation_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CloseOperation_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2164,11 +2482,18 @@ uint32_t TCLIService_CloseOperation_args::write(::apache::thrift::protocol::TPro
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CloseOperation_pargs::~TCLIService_CloseOperation_pargs() throw() {
+}
+
+
 uint32_t TCLIService_CloseOperation_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CloseOperation_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2177,9 +2502,15 @@ uint32_t TCLIService_CloseOperation_pargs::write(::apache::thrift::protocol::TPr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CloseOperation_result::~TCLIService_CloseOperation_result() throw() {
+}
+
+
 uint32_t TCLIService_CloseOperation_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2236,6 +2567,11 @@ uint32_t TCLIService_CloseOperation_result::write(::apache::thrift::protocol::TP
   return xfer;
 }
 
+
+TCLIService_CloseOperation_presult::~TCLIService_CloseOperation_presult() throw() {
+}
+
+
 uint32_t TCLIService_CloseOperation_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2276,6 +2612,11 @@ uint32_t TCLIService_CloseOperation_presult::read(::apache::thrift::protocol::TP
   return xfer;
 }
 
+
+TCLIService_GetResultSetMetadata_args::~TCLIService_GetResultSetMetadata_args() throw() {
+}
+
+
 uint32_t TCLIService_GetResultSetMetadata_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2318,6 +2659,7 @@ uint32_t TCLIService_GetResultSetMetadata_args::read(::apache::thrift::protocol:
 
 uint32_t TCLIService_GetResultSetMetadata_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetResultSetMetadata_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2326,11 +2668,18 @@ uint32_t TCLIService_GetResultSetMetadata_args::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetResultSetMetadata_pargs::~TCLIService_GetResultSetMetadata_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetResultSetMetadata_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetResultSetMetadata_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2339,9 +2688,15 @@ uint32_t TCLIService_GetResultSetMetadata_pargs::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetResultSetMetadata_result::~TCLIService_GetResultSetMetadata_result() throw() {
+}
+
+
 uint32_t TCLIService_GetResultSetMetadata_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2398,6 +2753,11 @@ uint32_t TCLIService_GetResultSetMetadata_result::write(::apache::thrift::protoc
   return xfer;
 }
 
+
+TCLIService_GetResultSetMetadata_presult::~TCLIService_GetResultSetMetadata_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetResultSetMetadata_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2438,6 +2798,11 @@ uint32_t TCLIService_GetResultSetMetadata_presult::read(::apache::thrift::protoc
   return xfer;
 }
 
+
+TCLIService_FetchResults_args::~TCLIService_FetchResults_args() throw() {
+}
+
+
 uint32_t TCLIService_FetchResults_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2480,6 +2845,7 @@ uint32_t TCLIService_FetchResults_args::read(::apache::thrift::protocol::TProtoc
 
 uint32_t TCLIService_FetchResults_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_FetchResults_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2488,11 +2854,18 @@ uint32_t TCLIService_FetchResults_args::write(::apache::thrift::protocol::TProto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_FetchResults_pargs::~TCLIService_FetchResults_pargs() throw() {
+}
+
+
 uint32_t TCLIService_FetchResults_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_FetchResults_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2501,9 +2874,15 @@ uint32_t TCLIService_FetchResults_pargs::write(::apache::thrift::protocol::TProt
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_FetchResults_result::~TCLIService_FetchResults_result() throw() {
+}
+
+
 uint32_t TCLIService_FetchResults_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2560,6 +2939,11 @@ uint32_t TCLIService_FetchResults_result::write(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_FetchResults_presult::~TCLIService_FetchResults_presult() throw() {
+}
+
+
 uint32_t TCLIService_FetchResults_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2600,6 +2984,11 @@ uint32_t TCLIService_FetchResults_presult::read(::apache::thrift::protocol::TPro
   return xfer;
 }
 
+
+TCLIService_GetDelegationToken_args::~TCLIService_GetDelegationToken_args() throw() {
+}
+
+
 uint32_t TCLIService_GetDelegationToken_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2642,6 +3031,7 @@ uint32_t TCLIService_GetDelegationToken_args::read(::apache::thrift::protocol::T
 
 uint32_t TCLIService_GetDelegationToken_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetDelegationToken_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2650,11 +3040,18 @@ uint32_t TCLIService_GetDelegationToken_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetDelegationToken_pargs::~TCLIService_GetDelegationToken_pargs() throw() {
+}
+
+
 uint32_t TCLIService_GetDelegationToken_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_GetDelegationToken_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2663,9 +3060,15 @@ uint32_t TCLIService_GetDelegationToken_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_GetDelegationToken_result::~TCLIService_GetDelegationToken_result() throw() {
+}
+
+
 uint32_t TCLIService_GetDelegationToken_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2722,6 +3125,11 @@ uint32_t TCLIService_GetDelegationToken_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+TCLIService_GetDelegationToken_presult::~TCLIService_GetDelegationToken_presult() throw() {
+}
+
+
 uint32_t TCLIService_GetDelegationToken_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2762,6 +3170,11 @@ uint32_t TCLIService_GetDelegationToken_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+TCLIService_CancelDelegationToken_args::~TCLIService_CancelDelegationToken_args() throw() {
+}
+
+
 uint32_t TCLIService_CancelDelegationToken_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2804,6 +3217,7 @@ uint32_t TCLIService_CancelDelegationToken_args::read(::apache::thrift::protocol
 
 uint32_t TCLIService_CancelDelegationToken_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CancelDelegationToken_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2812,11 +3226,18 @@ uint32_t TCLIService_CancelDelegationToken_args::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CancelDelegationToken_pargs::~TCLIService_CancelDelegationToken_pargs() throw() {
+}
+
+
 uint32_t TCLIService_CancelDelegationToken_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_CancelDelegationToken_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2825,9 +3246,15 @@ uint32_t TCLIService_CancelDelegationToken_pargs::write(::apache::thrift::protoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_CancelDelegationToken_result::~TCLIService_CancelDelegationToken_result() throw() {
+}
+
+
 uint32_t TCLIService_CancelDelegationToken_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2884,6 +3311,11 @@ uint32_t TCLIService_CancelDelegationToken_result::write(::apache::thrift::proto
   return xfer;
 }
 
+
+TCLIService_CancelDelegationToken_presult::~TCLIService_CancelDelegationToken_presult() throw() {
+}
+
+
 uint32_t TCLIService_CancelDelegationToken_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2924,6 +3356,11 @@ uint32_t TCLIService_CancelDelegationToken_presult::read(::apache::thrift::proto
   return xfer;
 }
 
+
+TCLIService_RenewDelegationToken_args::~TCLIService_RenewDelegationToken_args() throw() {
+}
+
+
 uint32_t TCLIService_RenewDelegationToken_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2966,6 +3403,7 @@ uint32_t TCLIService_RenewDelegationToken_args::read(::apache::thrift::protocol:
 
 uint32_t TCLIService_RenewDelegationToken_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_RenewDelegationToken_args");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2974,11 +3412,18 @@ uint32_t TCLIService_RenewDelegationToken_args::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_RenewDelegationToken_pargs::~TCLIService_RenewDelegationToken_pargs() throw() {
+}
+
+
 uint32_t TCLIService_RenewDelegationToken_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TCLIService_RenewDelegationToken_pargs");
 
   xfer += oprot->writeFieldBegin("req", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2987,9 +3432,15 @@ uint32_t TCLIService_RenewDelegationToken_pargs::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+TCLIService_RenewDelegationToken_result::~TCLIService_RenewDelegationToken_result() throw() {
+}
+
+
 uint32_t TCLIService_RenewDelegationToken_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3046,6 +3497,11 @@ uint32_t TCLIService_RenewDelegationToken_result::write(::apache::thrift::protoc
   return xfer;
 }
 
+
+TCLIService_RenewDelegationToken_presult::~TCLIService_RenewDelegationToken_presult() throw() {
+}
+
+
 uint32_t TCLIService_RenewDelegationToken_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;


[22/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning.q.out b/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning.q.out
new file mode 100644
index 0000000..a628aae
--- /dev/null
+++ b/ql/src/test/results/clientpositive/spark/spark_dynamic_partition_pruning.q.out
@@ -0,0 +1,5573 @@
+PREHOOK: query: -- SORT_QUERY_RESULTS
+
+select distinct ds from srcpart
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: -- SORT_QUERY_RESULTS
+
+select distinct ds from srcpart
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+2008-04-08
+2008-04-09
+PREHOOK: query: select distinct hr from srcpart
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: select distinct hr from srcpart
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+#### A masked pattern was here ####
+11
+12
+PREHOOK: query: EXPLAIN create table srcpart_date as select ds as ds, ds as date from srcpart group by ds
+PREHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: query: EXPLAIN create table srcpart_date as select ds as ds, ds as date from srcpart group by ds
+POSTHOOK: type: CREATETABLE_AS_SELECT
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+  Stage-3 depends on stages: Stage-0
+  Stage-2 depends on stages: Stage-3
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (GROUP, 2)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Select Operator
+                    expressions: ds (type: string)
+                    outputColumnNames: _col0
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    Group By Operator
+                      keys: _col0 (type: string)
+                      mode: hash
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                      Reduce Output Operator
+                        key expressions: _col0 (type: string)
+                        sort order: +
+                        Map-reduce partition columns: _col0 (type: string)
+                        Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                Select Operator
+                  expressions: _col0 (type: string), _col0 (type: string)
+                  outputColumnNames: _col0, _col1
+                  Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                  File Output Operator
+                    compressed: false
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    table:
+                        input format: org.apache.hadoop.mapred.TextInputFormat
+                        output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                        serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+                        name: default.srcpart_date
+
+  Stage: Stage-0
+    Move Operator
+      files:
+          hdfs directory: true
+#### A masked pattern was here ####
+
+  Stage: Stage-3
+      Create Table Operator:
+        Create Table
+          columns: ds string, date string
+          input format: org.apache.hadoop.mapred.TextInputFormat
+          output format: org.apache.hadoop.hive.ql.io.IgnoreKeyTextOutputFormat
+          serde name: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+          name: default.srcpart_date
+
+  Stage: Stage-2
+    Stats-Aggr Operator
+
+PREHOOK: query: create table srcpart_date as select ds as ds, ds as date from srcpart group by ds
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_date
+POSTHOOK: query: create table srcpart_date as select ds as ds, ds as date from srcpart group by ds
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_date
+PREHOOK: query: create table srcpart_hour as select hr as hr, hr as hour from srcpart group by hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_hour
+POSTHOOK: query: create table srcpart_hour as select hr as hr, hr as hour from srcpart group by hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_hour
+PREHOOK: query: create table srcpart_date_hour as select ds as ds, ds as date, hr as hr, hr as hour from srcpart group by ds, hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_date_hour
+POSTHOOK: query: create table srcpart_date_hour as select ds as ds, ds as date, hr as hr, hr as hour from srcpart group by ds, hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_date_hour
+PREHOOK: query: create table srcpart_double_hour as select (hr*2) as hr, hr as hour from srcpart group by hr
+PREHOOK: type: CREATETABLE_AS_SELECT
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Output: database:default
+PREHOOK: Output: default@srcpart_double_hour
+POSTHOOK: query: create table srcpart_double_hour as select (hr*2) as hr, hr as hour from srcpart group by hr
+POSTHOOK: type: CREATETABLE_AS_SELECT
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Output: database:default
+POSTHOOK: Output: default@srcpart_double_hour
+PREHOOK: query: -- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+PREHOOK: type: QUERY
+POSTHOOK: query: -- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+1000
+PREHOOK: query: select count(*) from srcpart where ds = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+#### A masked pattern was here ####
+1000
+PREHOOK: query: -- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 7 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+        Map 8 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 10 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: hr
+                          Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 5 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Map 6 (PARTITION-LEVEL SORT, 2), Reducer 2 (PARTITION-LEVEL SORT, 2)
+        Reducer 4 <- Reducer 3 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: hr (type: string)
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 10 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: string)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: string)
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                outputColumnNames: _col3
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col3 (type: string)
+                  sort order: +
+                  Map-reduce partition columns: _col3 (type: string)
+                  Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+        Reducer 3 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 _col3 (type: string)
+                  1 hr (type: string)
+                Statistics: Num rows: 2420 Data size: 25709 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 4 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+PREHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+POSTHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 5 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Map 6 (PARTITION-LEVEL SORT, 2), Reducer 2 (PARTITION-LEVEL SORT, 2)
+        Reducer 4 <- Reducer 3 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (ds is not null and hr is not null) (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: hr (type: string)
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = '2008-04-08')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 10 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: string)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: string)
+                      Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                outputColumnNames: _col3
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col3 (type: string)
+                  sort order: +
+                  Map-reduce partition columns: _col3 (type: string)
+                  Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+        Reducer 3 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 _col3 (type: string)
+                  1 hr (type: string)
+                Statistics: Num rows: 2420 Data size: 25709 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 4 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+PREHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+POSTHOOK: Input: default@srcpart_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: select count(*) from srcpart where hr = 11 and ds = '2008-04-08'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where hr = 11 and ds = '2008-04-08'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+500
+PREHOOK: query: -- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 108 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+        Map 6 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 108 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: hr
+                          Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string), hr (type: string)
+                    sort order: ++
+                    Map-reduce partition columns: ds (type: string), hr (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 108 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string), hr (type: string)
+                      sort order: ++
+                      Map-reduce partition columns: ds (type: string), hr (type: string)
+                      Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string), hr (type: string)
+                  1 ds (type: string), hr (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (ds is not null and hr is not null) (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string), hr (type: string)
+                    sort order: ++
+                    Map-reduce partition columns: ds (type: string), hr (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date_hour
+                  filterExpr: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 108 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (((ds is not null and hr is not null) and (date = '2008-04-08')) and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string), hr (type: string)
+                      sort order: ++
+                      Map-reduce partition columns: ds (type: string), hr (type: string)
+                      Statistics: Num rows: 1 Data size: 27 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string), hr (type: string)
+                  1 ds (type: string), hr (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date_hour
+#### A masked pattern was here ####
+500
+PREHOOK: query: select count(*) from srcpart where ds = '2008-04-08' and hr = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = '2008-04-08' and hr = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+#### A masked pattern was here ####
+500
+PREHOOK: query: -- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+PREHOOK: type: QUERY
+POSTHOOK: query: -- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: ds (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: ds
+                          Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                          target column name: ds
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+0
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: ds is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: ds (type: string)
+                    sort order: +
+                    Map-reduce partition columns: ds (type: string)
+                    Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_date
+                  filterExpr: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 42 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (ds is not null and (date = 'I DONT EXIST')) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: ds (type: string)
+                      sort order: +
+                      Map-reduce partition columns: ds (type: string)
+                      Statistics: Num rows: 1 Data size: 21 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 ds (type: string)
+                  1 ds (type: string)
+                Statistics: Num rows: 2200 Data size: 23372 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_date
+#### A masked pattern was here ####
+0
+PREHOOK: query: select count(*) from srcpart where ds = 'I DONT EXIST'
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where ds = 'I DONT EXIST'
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+#### A masked pattern was here ####
+0
+PREHOOK: query: -- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: -- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: double)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: UDFToDouble(hr)
+                          Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: UDFToDouble(hr) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: UDFToDouble(hr) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(hr) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(hr) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 UDFToDouble(hr) (type: double)
+                  1 UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: hr (type: double)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: double)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                        Spark Partition Pruning Sink Operator
+                          partition key expr: (hr * 2)
+                          Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                          target column name: hr
+                          target work: Map 1
+
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (hr * 2) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr * 2) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: (hr * 2) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: (hr * 2) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: double)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: double)
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 (hr * 2) (type: double)
+                  1 hr (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: UDFToDouble(hr) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: UDFToDouble(hr) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(hr) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(hr) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToDouble(UDFToInteger((hr / 2))) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 UDFToDouble(hr) (type: double)
+                  1 UDFToDouble(UDFToInteger((hr / 2))) (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Spark
+      Edges:
+        Reducer 2 <- Map 1 (PARTITION-LEVEL SORT, 2), Map 4 (PARTITION-LEVEL SORT, 2)
+        Reducer 3 <- Reducer 2 (GROUP, 1)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart
+                  filterExpr: (hr * 2) is not null (type: boolean)
+                  Statistics: Num rows: 2000 Data size: 21248 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr * 2) is not null (type: boolean)
+                    Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: (hr * 2) (type: double)
+                      sort order: +
+                      Map-reduce partition columns: (hr * 2) (type: double)
+                      Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
+        Map 4 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (hr is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (hr is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Reduce Output Operator
+                      key expressions: hr (type: double)
+                      sort order: +
+                      Map-reduce partition columns: hr (type: double)
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+        Reducer 2 
+            Reduce Operator Tree:
+              Join Operator
+                condition map:
+                     Inner Join 0 to 1
+                keys:
+                  0 (hr * 2) (type: double)
+                  1 hr (type: double)
+                Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  aggregations: count()
+                  mode: hash
+                  outputColumnNames: _col0
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    sort order: 
+                    Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                    value expressions: _col0 (type: bigint)
+        Reducer 3 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                mode: mergepartial
+                outputColumnNames: _col0
+                Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
+                  table:
+                      input format: org.apache.hadoop.mapred.TextInputFormat
+                      output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                      serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+PREHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=12
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=12
+POSTHOOK: Input: default@srcpart_double_hour
+#### A masked pattern was here ####
+1000
+PREHOOK: query: select count(*) from srcpart where hr = 11
+PREHOOK: type: QUERY
+PREHOOK: Input: default@srcpart
+PREHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+PREHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+#### A masked pattern was here ####
+POSTHOOK: query: select count(*) from srcpart where hr = 11
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@srcpart
+POSTHOOK: Input: default@srcpart@ds=2008-04-08/hr=11
+POSTHOOK: Input: default@srcpart@ds=2008-04-09/hr=11
+#### A masked pattern was here ####
+1000
+PREHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-2 is a root stage
+  Stage-1 depends on stages: Stage-2
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-2
+    Spark
+#### A masked pattern was here ####
+      Vertices:
+        Map 5 
+            Map Operator Tree:
+                TableScan
+                  alias: srcpart_double_hour
+                  filterExpr: (UDFToString(hr) is not null and (hour = 11)) (type: boolean)
+                  Statistics: Num rows: 2 Data size: 14 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: (UDFToString(hr) is not null and (hour = 11)) (type: boolean)
+                    Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                    Select Operator
+                      expressions: UDFToString(hr) (type: string)
+                      outputColumnNames: _col0
+                      Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                      Group By Operator
+                        keys: _col0 (type: string)
+                        mode: hash
+                        outputColumnNames: _col0
+                        Statistics: Num rows: 1 Data size: 7 Basic stats: COMPLETE Column stats: NONE
+                        Spark Pa

<TRUNCATED>

[42/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AbortTxnRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AbortTxnRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AbortTxnRequest.java
index 5d44585..18c55f1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AbortTxnRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AbortTxnRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AbortTxnRequest implements org.apache.thrift.TBase<AbortTxnRequest, AbortTxnRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AbortTxnRequest implements org.apache.thrift.TBase<AbortTxnRequest, AbortTxnRequest._Fields>, java.io.Serializable, Cloneable, Comparable<AbortTxnRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AbortTxnRequest");
 
   private static final org.apache.thrift.protocol.TField TXNID_FIELD_DESC = new org.apache.thrift.protocol.TField("txnid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class AbortTxnRequest implements org.apache.thrift.TBase<AbortTxnRequest,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txnid = true;
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AbortTxnRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AbortTxnRequest typedOther = (AbortTxnRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddDynamicPartitions.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddDynamicPartitions.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddDynamicPartitions.java
index afb2b79..6caf00e 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddDynamicPartitions.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddDynamicPartitions.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicPartitions, AddDynamicPartitions._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicPartitions, AddDynamicPartitions._Fields>, java.io.Serializable, Cloneable, Comparable<AddDynamicPartitions> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AddDynamicPartitions");
 
   private static final org.apache.thrift.protocol.TField TXNID_FIELD_DESC = new org.apache.thrift.protocol.TField("txnid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -166,10 +170,7 @@ public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicP
       this.tablename = other.tablename;
     }
     if (other.isSetPartitionnames()) {
-      List<String> __this__partitionnames = new ArrayList<String>();
-      for (String other_element : other.partitionnames) {
-        __this__partitionnames.add(other_element);
-      }
+      List<String> __this__partitionnames = new ArrayList<String>(other.partitionnames);
       this.partitionnames = __this__partitionnames;
     }
   }
@@ -421,75 +422,75 @@ public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicP
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txnid = true;
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
     boolean present_dbname = true && (isSetDbname());
-    builder.append(present_dbname);
+    list.add(present_dbname);
     if (present_dbname)
-      builder.append(dbname);
+      list.add(dbname);
 
     boolean present_tablename = true && (isSetTablename());
-    builder.append(present_tablename);
+    list.add(present_tablename);
     if (present_tablename)
-      builder.append(tablename);
+      list.add(tablename);
 
     boolean present_partitionnames = true && (isSetPartitionnames());
-    builder.append(present_partitionnames);
+    list.add(present_partitionnames);
     if (present_partitionnames)
-      builder.append(partitionnames);
+      list.add(partitionnames);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AddDynamicPartitions other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AddDynamicPartitions typedOther = (AddDynamicPartitions)other;
 
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(typedOther.isSetDbname());
+    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(other.isSetDbname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, typedOther.dbname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, other.dbname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(typedOther.isSetTablename());
+    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(other.isSetTablename());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTablename()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, typedOther.tablename);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, other.tablename);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionnames()).compareTo(typedOther.isSetPartitionnames());
+    lastComparison = Boolean.valueOf(isSetPartitionnames()).compareTo(other.isSetPartitionnames());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionnames()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionnames, typedOther.partitionnames);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionnames, other.partitionnames);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -631,11 +632,11 @@ public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicP
               {
                 org.apache.thrift.protocol.TList _list492 = iprot.readListBegin();
                 struct.partitionnames = new ArrayList<String>(_list492.size);
-                for (int _i493 = 0; _i493 < _list492.size; ++_i493)
+                String _elem493;
+                for (int _i494 = 0; _i494 < _list492.size; ++_i494)
                 {
-                  String _elem494; // optional
-                  _elem494 = iprot.readString();
-                  struct.partitionnames.add(_elem494);
+                  _elem493 = iprot.readString();
+                  struct.partitionnames.add(_elem493);
                 }
                 iprot.readListEnd();
               }
@@ -723,11 +724,11 @@ public class AddDynamicPartitions implements org.apache.thrift.TBase<AddDynamicP
       {
         org.apache.thrift.protocol.TList _list497 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.partitionnames = new ArrayList<String>(_list497.size);
-        for (int _i498 = 0; _i498 < _list497.size; ++_i498)
+        String _elem498;
+        for (int _i499 = 0; _i499 < _list497.size; ++_i499)
         {
-          String _elem499; // optional
-          _elem499 = iprot.readString();
-          struct.partitionnames.add(_elem499);
+          _elem498 = iprot.readString();
+          struct.partitionnames.add(_elem498);
         }
       }
       struct.setPartitionnamesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java
index 7bb72ba..00ab06f 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitionsRequest, AddPartitionsRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitionsRequest, AddPartitionsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<AddPartitionsRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AddPartitionsRequest");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -126,7 +130,7 @@ public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitio
   private static final int __IFNOTEXISTS_ISSET_ID = 0;
   private static final int __NEEDRESULT_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.NEED_RESULT};
+  private static final _Fields optionals[] = {_Fields.NEED_RESULT};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -176,7 +180,7 @@ public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitio
       this.tblName = other.tblName;
     }
     if (other.isSetParts()) {
-      List<Partition> __this__parts = new ArrayList<Partition>();
+      List<Partition> __this__parts = new ArrayList<Partition>(other.parts.size());
       for (Partition other_element : other.parts) {
         __this__parts.add(new Partition(other_element));
       }
@@ -479,90 +483,90 @@ public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitio
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tblName = true && (isSetTblName());
-    builder.append(present_tblName);
+    list.add(present_tblName);
     if (present_tblName)
-      builder.append(tblName);
+      list.add(tblName);
 
     boolean present_parts = true && (isSetParts());
-    builder.append(present_parts);
+    list.add(present_parts);
     if (present_parts)
-      builder.append(parts);
+      list.add(parts);
 
     boolean present_ifNotExists = true;
-    builder.append(present_ifNotExists);
+    list.add(present_ifNotExists);
     if (present_ifNotExists)
-      builder.append(ifNotExists);
+      list.add(ifNotExists);
 
     boolean present_needResult = true && (isSetNeedResult());
-    builder.append(present_needResult);
+    list.add(present_needResult);
     if (present_needResult)
-      builder.append(needResult);
+      list.add(needResult);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AddPartitionsRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AddPartitionsRequest typedOther = (AddPartitionsRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(typedOther.isSetTblName());
+    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(other.isSetTblName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTblName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, typedOther.tblName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, other.tblName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParts()).compareTo(typedOther.isSetParts());
+    lastComparison = Boolean.valueOf(isSetParts()).compareTo(other.isSetParts());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParts()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parts, typedOther.parts);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parts, other.parts);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetIfNotExists()).compareTo(typedOther.isSetIfNotExists());
+    lastComparison = Boolean.valueOf(isSetIfNotExists()).compareTo(other.isSetIfNotExists());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIfNotExists()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ifNotExists, typedOther.ifNotExists);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ifNotExists, other.ifNotExists);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNeedResult()).compareTo(typedOther.isSetNeedResult());
+    lastComparison = Boolean.valueOf(isSetNeedResult()).compareTo(other.isSetNeedResult());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNeedResult()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.needResult, typedOther.needResult);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.needResult, other.needResult);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -702,12 +706,12 @@ public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitio
               {
                 org.apache.thrift.protocol.TList _list388 = iprot.readListBegin();
                 struct.parts = new ArrayList<Partition>(_list388.size);
-                for (int _i389 = 0; _i389 < _list388.size; ++_i389)
+                Partition _elem389;
+                for (int _i390 = 0; _i390 < _list388.size; ++_i390)
                 {
-                  Partition _elem390; // optional
-                  _elem390 = new Partition();
-                  _elem390.read(iprot);
-                  struct.parts.add(_elem390);
+                  _elem389 = new Partition();
+                  _elem389.read(iprot);
+                  struct.parts.add(_elem389);
                 }
                 iprot.readListEnd();
               }
@@ -822,12 +826,12 @@ public class AddPartitionsRequest implements org.apache.thrift.TBase<AddPartitio
       {
         org.apache.thrift.protocol.TList _list393 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.parts = new ArrayList<Partition>(_list393.size);
-        for (int _i394 = 0; _i394 < _list393.size; ++_i394)
+        Partition _elem394;
+        for (int _i395 = 0; _i395 < _list393.size; ++_i395)
         {
-          Partition _elem395; // optional
-          _elem395 = new Partition();
-          _elem395.read(iprot);
-          struct.parts.add(_elem395);
+          _elem394 = new Partition();
+          _elem394.read(iprot);
+          struct.parts.add(_elem394);
         }
       }
       struct.setPartsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java
index 875e04a..27276c2 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartitionsResult, AddPartitionsResult._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartitionsResult, AddPartitionsResult._Fields>, java.io.Serializable, Cloneable, Comparable<AddPartitionsResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AddPartitionsResult");
 
   private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -103,7 +107,7 @@ public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartition
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.PARTITIONS};
+  private static final _Fields optionals[] = {_Fields.PARTITIONS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -122,7 +126,7 @@ public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartition
    */
   public AddPartitionsResult(AddPartitionsResult other) {
     if (other.isSetPartitions()) {
-      List<Partition> __this__partitions = new ArrayList<Partition>();
+      List<Partition> __this__partitions = new ArrayList<Partition>(other.partitions.size());
       for (Partition other_element : other.partitions) {
         __this__partitions.add(new Partition(other_element));
       }
@@ -239,30 +243,30 @@ public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartition
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partitions = true && (isSetPartitions());
-    builder.append(present_partitions);
+    list.add(present_partitions);
     if (present_partitions)
-      builder.append(partitions);
+      list.add(partitions);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AddPartitionsResult other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AddPartitionsResult typedOther = (AddPartitionsResult)other;
 
-    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(typedOther.isSetPartitions());
+    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, typedOther.partitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -344,12 +348,12 @@ public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartition
               {
                 org.apache.thrift.protocol.TList _list380 = iprot.readListBegin();
                 struct.partitions = new ArrayList<Partition>(_list380.size);
-                for (int _i381 = 0; _i381 < _list380.size; ++_i381)
+                Partition _elem381;
+                for (int _i382 = 0; _i382 < _list380.size; ++_i382)
                 {
-                  Partition _elem382; // optional
-                  _elem382 = new Partition();
-                  _elem382.read(iprot);
-                  struct.partitions.add(_elem382);
+                  _elem381 = new Partition();
+                  _elem381.read(iprot);
+                  struct.partitions.add(_elem381);
                 }
                 iprot.readListEnd();
               }
@@ -426,12 +430,12 @@ public class AddPartitionsResult implements org.apache.thrift.TBase<AddPartition
         {
           org.apache.thrift.protocol.TList _list385 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.partitions = new ArrayList<Partition>(_list385.size);
-          for (int _i386 = 0; _i386 < _list385.size; ++_i386)
+          Partition _elem386;
+          for (int _i387 = 0; _i387 < _list385.size; ++_i387)
           {
-            Partition _elem387; // optional
-            _elem387 = new Partition();
-            _elem387.read(iprot);
-            struct.partitions.add(_elem387);
+            _elem386 = new Partition();
+            _elem386.read(iprot);
+            struct.partitions.add(_elem386);
           }
         }
         struct.setPartitionsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AggrStats.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AggrStats.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AggrStats.java
index 0e1dbcb..306755d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AggrStats.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AggrStats.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._Fields>, java.io.Serializable, Cloneable, Comparable<AggrStats> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AggrStats");
 
   private static final org.apache.thrift.protocol.TField COL_STATS_FIELD_DESC = new org.apache.thrift.protocol.TField("colStats", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -141,7 +145,7 @@ public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._
   public AggrStats(AggrStats other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetColStats()) {
-      List<ColumnStatisticsObj> __this__colStats = new ArrayList<ColumnStatisticsObj>();
+      List<ColumnStatisticsObj> __this__colStats = new ArrayList<ColumnStatisticsObj>(other.colStats.size());
       for (ColumnStatisticsObj other_element : other.colStats) {
         __this__colStats.add(new ColumnStatisticsObj(other_element));
       }
@@ -305,45 +309,45 @@ public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_colStats = true && (isSetColStats());
-    builder.append(present_colStats);
+    list.add(present_colStats);
     if (present_colStats)
-      builder.append(colStats);
+      list.add(colStats);
 
     boolean present_partsFound = true;
-    builder.append(present_partsFound);
+    list.add(present_partsFound);
     if (present_partsFound)
-      builder.append(partsFound);
+      list.add(partsFound);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AggrStats other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AggrStats typedOther = (AggrStats)other;
 
-    lastComparison = Boolean.valueOf(isSetColStats()).compareTo(typedOther.isSetColStats());
+    lastComparison = Boolean.valueOf(isSetColStats()).compareTo(other.isSetColStats());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColStats()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colStats, typedOther.colStats);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colStats, other.colStats);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartsFound()).compareTo(typedOther.isSetPartsFound());
+    lastComparison = Boolean.valueOf(isSetPartsFound()).compareTo(other.isSetPartsFound());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartsFound()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partsFound, typedOther.partsFound);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partsFound, other.partsFound);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -437,12 +441,12 @@ public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._
               {
                 org.apache.thrift.protocol.TList _list278 = iprot.readListBegin();
                 struct.colStats = new ArrayList<ColumnStatisticsObj>(_list278.size);
-                for (int _i279 = 0; _i279 < _list278.size; ++_i279)
+                ColumnStatisticsObj _elem279;
+                for (int _i280 = 0; _i280 < _list278.size; ++_i280)
                 {
-                  ColumnStatisticsObj _elem280; // optional
-                  _elem280 = new ColumnStatisticsObj();
-                  _elem280.read(iprot);
-                  struct.colStats.add(_elem280);
+                  _elem279 = new ColumnStatisticsObj();
+                  _elem279.read(iprot);
+                  struct.colStats.add(_elem279);
                 }
                 iprot.readListEnd();
               }
@@ -520,12 +524,12 @@ public class AggrStats implements org.apache.thrift.TBase<AggrStats, AggrStats._
       {
         org.apache.thrift.protocol.TList _list283 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.colStats = new ArrayList<ColumnStatisticsObj>(_list283.size);
-        for (int _i284 = 0; _i284 < _list283.size; ++_i284)
+        ColumnStatisticsObj _elem284;
+        for (int _i285 = 0; _i285 < _list283.size; ++_i285)
         {
-          ColumnStatisticsObj _elem285; // optional
-          _elem285 = new ColumnStatisticsObj();
-          _elem285.read(iprot);
-          struct.colStats.add(_elem285);
+          _elem284 = new ColumnStatisticsObj();
+          _elem284.read(iprot);
+          struct.colStats.add(_elem284);
         }
       }
       struct.setColStatsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlreadyExistsException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlreadyExistsException.java
index 2a5e58f..6081564 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlreadyExistsException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlreadyExistsException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class AlreadyExistsException extends TException implements org.apache.thrift.TBase<AlreadyExistsException, AlreadyExistsException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class AlreadyExistsException extends TException implements org.apache.thrift.TBase<AlreadyExistsException, AlreadyExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<AlreadyExistsException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AlreadyExistsException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class AlreadyExistsException extends TException implements org.apache.thr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(AlreadyExistsException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    AlreadyExistsException typedOther = (AlreadyExistsException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BinaryColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BinaryColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BinaryColumnStatsData.java
index 1516b25..3462576 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BinaryColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BinaryColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class BinaryColumnStatsData implements org.apache.thrift.TBase<BinaryColumnStatsData, BinaryColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class BinaryColumnStatsData implements org.apache.thrift.TBase<BinaryColumnStatsData, BinaryColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<BinaryColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("BinaryColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField MAX_COL_LEN_FIELD_DESC = new org.apache.thrift.protocol.TField("maxColLen", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -343,60 +347,60 @@ public class BinaryColumnStatsData implements org.apache.thrift.TBase<BinaryColu
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_maxColLen = true;
-    builder.append(present_maxColLen);
+    list.add(present_maxColLen);
     if (present_maxColLen)
-      builder.append(maxColLen);
+      list.add(maxColLen);
 
     boolean present_avgColLen = true;
-    builder.append(present_avgColLen);
+    list.add(present_avgColLen);
     if (present_avgColLen)
-      builder.append(avgColLen);
+      list.add(avgColLen);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(BinaryColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    BinaryColumnStatsData typedOther = (BinaryColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetMaxColLen()).compareTo(typedOther.isSetMaxColLen());
+    lastComparison = Boolean.valueOf(isSetMaxColLen()).compareTo(other.isSetMaxColLen());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxColLen()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxColLen, typedOther.maxColLen);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxColLen, other.maxColLen);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAvgColLen()).compareTo(typedOther.isSetAvgColLen());
+    lastComparison = Boolean.valueOf(isSetAvgColLen()).compareTo(other.isSetAvgColLen());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAvgColLen()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.avgColLen, typedOther.avgColLen);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.avgColLen, other.avgColLen);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BooleanColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BooleanColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BooleanColumnStatsData.java
index 9ef9c0f..9b87007 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BooleanColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/BooleanColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class BooleanColumnStatsData implements org.apache.thrift.TBase<BooleanColumnStatsData, BooleanColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class BooleanColumnStatsData implements org.apache.thrift.TBase<BooleanColumnStatsData, BooleanColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<BooleanColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("BooleanColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField NUM_TRUES_FIELD_DESC = new org.apache.thrift.protocol.TField("numTrues", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -343,60 +347,60 @@ public class BooleanColumnStatsData implements org.apache.thrift.TBase<BooleanCo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_numTrues = true;
-    builder.append(present_numTrues);
+    list.add(present_numTrues);
     if (present_numTrues)
-      builder.append(numTrues);
+      list.add(numTrues);
 
     boolean present_numFalses = true;
-    builder.append(present_numFalses);
+    list.add(present_numFalses);
     if (present_numFalses)
-      builder.append(numFalses);
+      list.add(numFalses);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(BooleanColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    BooleanColumnStatsData typedOther = (BooleanColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetNumTrues()).compareTo(typedOther.isSetNumTrues());
+    lastComparison = Boolean.valueOf(isSetNumTrues()).compareTo(other.isSetNumTrues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumTrues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numTrues, typedOther.numTrues);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numTrues, other.numTrues);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumFalses()).compareTo(typedOther.isSetNumFalses());
+    lastComparison = Boolean.valueOf(isSetNumFalses()).compareTo(other.isSetNumFalses());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumFalses()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numFalses, typedOther.numFalses);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numFalses, other.numFalses);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CheckLockRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CheckLockRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CheckLockRequest.java
index ae34203..a229476 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CheckLockRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CheckLockRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class CheckLockRequest implements org.apache.thrift.TBase<CheckLockRequest, CheckLockRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class CheckLockRequest implements org.apache.thrift.TBase<CheckLockRequest, CheckLockRequest._Fields>, java.io.Serializable, Cloneable, Comparable<CheckLockRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CheckLockRequest");
 
   private static final org.apache.thrift.protocol.TField LOCKID_FIELD_DESC = new org.apache.thrift.protocol.TField("lockid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class CheckLockRequest implements org.apache.thrift.TBase<CheckLockReques
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lockid = true;
-    builder.append(present_lockid);
+    list.add(present_lockid);
     if (present_lockid)
-      builder.append(lockid);
+      list.add(lockid);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(CheckLockRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    CheckLockRequest typedOther = (CheckLockRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(typedOther.isSetLockid());
+    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(other.isSetLockid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLockid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, typedOther.lockid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, other.lockid);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java
index b34619f..fdd96ec 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistics, ColumnStatistics._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistics, ColumnStatistics._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnStatistics> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnStatistics");
 
   private static final org.apache.thrift.protocol.TField STATS_DESC_FIELD_DESC = new org.apache.thrift.protocol.TField("statsDesc", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -140,7 +144,7 @@ public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistic
       this.statsDesc = new ColumnStatisticsDesc(other.statsDesc);
     }
     if (other.isSetStatsObj()) {
-      List<ColumnStatisticsObj> __this__statsObj = new ArrayList<ColumnStatisticsObj>();
+      List<ColumnStatisticsObj> __this__statsObj = new ArrayList<ColumnStatisticsObj>(other.statsObj.size());
       for (ColumnStatisticsObj other_element : other.statsObj) {
         __this__statsObj.add(new ColumnStatisticsObj(other_element));
       }
@@ -303,45 +307,45 @@ public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistic
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_statsDesc = true && (isSetStatsDesc());
-    builder.append(present_statsDesc);
+    list.add(present_statsDesc);
     if (present_statsDesc)
-      builder.append(statsDesc);
+      list.add(statsDesc);
 
     boolean present_statsObj = true && (isSetStatsObj());
-    builder.append(present_statsObj);
+    list.add(present_statsObj);
     if (present_statsObj)
-      builder.append(statsObj);
+      list.add(statsObj);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ColumnStatistics other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ColumnStatistics typedOther = (ColumnStatistics)other;
 
-    lastComparison = Boolean.valueOf(isSetStatsDesc()).compareTo(typedOther.isSetStatsDesc());
+    lastComparison = Boolean.valueOf(isSetStatsDesc()).compareTo(other.isSetStatsDesc());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatsDesc()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsDesc, typedOther.statsDesc);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsDesc, other.statsDesc);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStatsObj()).compareTo(typedOther.isSetStatsObj());
+    lastComparison = Boolean.valueOf(isSetStatsObj()).compareTo(other.isSetStatsObj());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatsObj()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsObj, typedOther.statsObj);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsObj, other.statsObj);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -449,12 +453,12 @@ public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistic
               {
                 org.apache.thrift.protocol.TList _list270 = iprot.readListBegin();
                 struct.statsObj = new ArrayList<ColumnStatisticsObj>(_list270.size);
-                for (int _i271 = 0; _i271 < _list270.size; ++_i271)
+                ColumnStatisticsObj _elem271;
+                for (int _i272 = 0; _i272 < _list270.size; ++_i272)
                 {
-                  ColumnStatisticsObj _elem272; // optional
-                  _elem272 = new ColumnStatisticsObj();
-                  _elem272.read(iprot);
-                  struct.statsObj.add(_elem272);
+                  _elem271 = new ColumnStatisticsObj();
+                  _elem271.read(iprot);
+                  struct.statsObj.add(_elem271);
                 }
                 iprot.readListEnd();
               }
@@ -529,12 +533,12 @@ public class ColumnStatistics implements org.apache.thrift.TBase<ColumnStatistic
       {
         org.apache.thrift.protocol.TList _list275 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.statsObj = new ArrayList<ColumnStatisticsObj>(_list275.size);
-        for (int _i276 = 0; _i276 < _list275.size; ++_i276)
+        ColumnStatisticsObj _elem276;
+        for (int _i277 = 0; _i277 < _list275.size; ++_i277)
         {
-          ColumnStatisticsObj _elem277; // optional
-          _elem277 = new ColumnStatisticsObj();
-          _elem277.read(iprot);
-          struct.statsObj.add(_elem277);
+          _elem276 = new ColumnStatisticsObj();
+          _elem276.read(iprot);
+          struct.statsObj.add(_elem276);
         }
       }
       struct.setStatsObjIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsData.java
index 58177e5..6558add 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class ColumnStatisticsData extends org.apache.thrift.TUnion<ColumnStatisticsData, ColumnStatisticsData._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnStatisticsData");
   private static final org.apache.thrift.protocol.TField BOOLEAN_STATS_FIELD_DESC = new org.apache.thrift.protocol.TField("booleanStats", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -318,6 +321,7 @@ public class ColumnStatisticsData extends org.apache.thrift.TUnion<ColumnStatist
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -636,19 +640,19 @@ public class ColumnStatisticsData extends org.apache.thrift.TUnion<ColumnStatist
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsDesc.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsDesc.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsDesc.java
index e951d04..f667bc5 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsDesc.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsDesc.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ColumnStatisticsDesc implements org.apache.thrift.TBase<ColumnStatisticsDesc, ColumnStatisticsDesc._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ColumnStatisticsDesc implements org.apache.thrift.TBase<ColumnStatisticsDesc, ColumnStatisticsDesc._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnStatisticsDesc> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnStatisticsDesc");
 
   private static final org.apache.thrift.protocol.TField IS_TBL_LEVEL_FIELD_DESC = new org.apache.thrift.protocol.TField("isTblLevel", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -126,7 +130,7 @@ public class ColumnStatisticsDesc implements org.apache.thrift.TBase<ColumnStati
   private static final int __ISTBLLEVEL_ISSET_ID = 0;
   private static final int __LASTANALYZED_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PART_NAME,_Fields.LAST_ANALYZED};
+  private static final _Fields optionals[] = {_Fields.PART_NAME,_Fields.LAST_ANALYZED};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -455,90 +459,90 @@ public class ColumnStatisticsDesc implements org.apache.thrift.TBase<ColumnStati
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_isTblLevel = true;
-    builder.append(present_isTblLevel);
+    list.add(present_isTblLevel);
     if (present_isTblLevel)
-      builder.append(isTblLevel);
+      list.add(isTblLevel);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_partName = true && (isSetPartName());
-    builder.append(present_partName);
+    list.add(present_partName);
     if (present_partName)
-      builder.append(partName);
+      list.add(partName);
 
     boolean present_lastAnalyzed = true && (isSetLastAnalyzed());
-    builder.append(present_lastAnalyzed);
+    list.add(present_lastAnalyzed);
     if (present_lastAnalyzed)
-      builder.append(lastAnalyzed);
+      list.add(lastAnalyzed);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ColumnStatisticsDesc other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ColumnStatisticsDesc typedOther = (ColumnStatisticsDesc)other;
 
-    lastComparison = Boolean.valueOf(isSetIsTblLevel()).compareTo(typedOther.isSetIsTblLevel());
+    lastComparison = Boolean.valueOf(isSetIsTblLevel()).compareTo(other.isSetIsTblLevel());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIsTblLevel()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.isTblLevel, typedOther.isTblLevel);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.isTblLevel, other.isTblLevel);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartName()).compareTo(typedOther.isSetPartName());
+    lastComparison = Boolean.valueOf(isSetPartName()).compareTo(other.isSetPartName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partName, typedOther.partName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partName, other.partName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastAnalyzed()).compareTo(typedOther.isSetLastAnalyzed());
+    lastComparison = Boolean.valueOf(isSetLastAnalyzed()).compareTo(other.isSetLastAnalyzed());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastAnalyzed()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAnalyzed, typedOther.lastAnalyzed);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAnalyzed, other.lastAnalyzed);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsObj.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsObj.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsObj.java
index f1257fd..8554ad1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsObj.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatisticsObj.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ColumnStatisticsObj implements org.apache.thrift.TBase<ColumnStatisticsObj, ColumnStatisticsObj._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ColumnStatisticsObj implements org.apache.thrift.TBase<ColumnStatisticsObj, ColumnStatisticsObj._Fields>, java.io.Serializable, Cloneable, Comparable<ColumnStatisticsObj> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ColumnStatisticsObj");
 
   private static final org.apache.thrift.protocol.TField COL_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("colName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -341,60 +345,60 @@ public class ColumnStatisticsObj implements org.apache.thrift.TBase<ColumnStatis
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_colName = true && (isSetColName());
-    builder.append(present_colName);
+    list.add(present_colName);
     if (present_colName)
-      builder.append(colName);
+      list.add(colName);
 
     boolean present_colType = true && (isSetColType());
-    builder.append(present_colType);
+    list.add(present_colType);
     if (present_colType)
-      builder.append(colType);
+      list.add(colType);
 
     boolean present_statsData = true && (isSetStatsData());
-    builder.append(present_statsData);
+    list.add(present_statsData);
     if (present_statsData)
-      builder.append(statsData);
+      list.add(statsData);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ColumnStatisticsObj other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ColumnStatisticsObj typedOther = (ColumnStatisticsObj)other;
 
-    lastComparison = Boolean.valueOf(isSetColName()).compareTo(typedOther.isSetColName());
+    lastComparison = Boolean.valueOf(isSetColName()).compareTo(other.isSetColName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colName, typedOther.colName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colName, other.colName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColType()).compareTo(typedOther.isSetColType());
+    lastComparison = Boolean.valueOf(isSetColType()).compareTo(other.isSetColType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colType, typedOther.colType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colType, other.colType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStatsData()).compareTo(typedOther.isSetStatsData());
+    lastComparison = Boolean.valueOf(isSetStatsData()).compareTo(other.isSetStatsData());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatsData()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsData, typedOther.statsData);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statsData, other.statsData);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CommitTxnRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CommitTxnRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CommitTxnRequest.java
index aeb2421..48c912a 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CommitTxnRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CommitTxnRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class CommitTxnRequest implements org.apache.thrift.TBase<CommitTxnRequest, CommitTxnRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class CommitTxnRequest implements org.apache.thrift.TBase<CommitTxnRequest, CommitTxnRequest._Fields>, java.io.Serializable, Cloneable, Comparable<CommitTxnRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CommitTxnRequest");
 
   private static final org.apache.thrift.protocol.TField TXNID_FIELD_DESC = new org.apache.thrift.protocol.TField("txnid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class CommitTxnRequest implements org.apache.thrift.TBase<CommitTxnReques
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txnid = true;
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(CommitTxnRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    CommitTxnRequest typedOther = (CommitTxnRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }


[28/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
index 4cc54e8..e299906 100644
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -67,7 +67,7 @@ class Iface(fb303.FacebookService.Iface):
     """
     pass
 
-  def get_all_databases(self, ):
+  def get_all_databases(self):
     pass
 
   def alter_database(self, dbname, db):
@@ -789,7 +789,7 @@ class Iface(fb303.FacebookService.Iface):
     """
     pass
 
-  def get_role_names(self, ):
+  def get_role_names(self):
     pass
 
   def grant_role(self, role_name, principal_name, principal_type, grantor, grantorType, grant_option):
@@ -911,10 +911,10 @@ class Iface(fb303.FacebookService.Iface):
     """
     pass
 
-  def get_open_txns(self, ):
+  def get_open_txns(self):
     pass
 
-  def get_open_txns_info(self, ):
+  def get_open_txns_info(self):
     pass
 
   def open_txns(self, rqst):
@@ -1008,7 +1008,7 @@ class Iface(fb303.FacebookService.Iface):
     """
     pass
 
-  def get_current_notificationEventId(self, ):
+  def get_current_notificationEventId(self):
     pass
 
   def fire_listener_event(self, rqst):
@@ -1042,16 +1042,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_getMetaConf(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_getMetaConf(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = getMetaConf_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1076,16 +1077,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_setMetaConf(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_setMetaConf(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = setMetaConf_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     return
@@ -1106,16 +1108,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_database(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_database(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_database_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1140,16 +1143,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_database(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_database(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_database_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1178,16 +1182,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_database(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_database(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_database_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1212,43 +1217,45 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_databases(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_databases(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_databases_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
       raise result.o1
     raise TApplicationException(TApplicationException.MISSING_RESULT, "get_databases failed: unknown result");
 
-  def get_all_databases(self, ):
+  def get_all_databases(self):
     self.send_get_all_databases()
     return self.recv_get_all_databases()
 
-  def send_get_all_databases(self, ):
+  def send_get_all_databases(self):
     self._oprot.writeMessageBegin('get_all_databases', TMessageType.CALL, self._seqid)
     args = get_all_databases_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_all_databases(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_all_databases(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_all_databases_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1273,16 +1280,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_database(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_database(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_database_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1305,16 +1313,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_type(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_type(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_type_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1339,16 +1348,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_type(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_type(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_type_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1375,16 +1385,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_type(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_type(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_type_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1409,16 +1420,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_type_all(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_type_all(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_type_all_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o2 is not None:
@@ -1443,16 +1455,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_fields(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_fields(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_fields_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1483,16 +1496,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_fields_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_fields_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_fields_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1521,16 +1535,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_schema(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_schema(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_schema_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1561,16 +1576,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_schema_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_schema_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_schema_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1597,16 +1613,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_table(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_table(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_table_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1635,16 +1652,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_table_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_table_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_table_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1675,16 +1693,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_table(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_table(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_table_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o3 is not None:
@@ -1713,16 +1732,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_table_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_table_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_table_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o3 is not None:
@@ -1747,16 +1767,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_tables(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_tables(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_tables_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1779,16 +1800,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_all_tables(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_all_tables(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_all_tables_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1813,16 +1835,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_table(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_table(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_table_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1849,16 +1872,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_table_objects_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_table_objects_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_table_objects_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1889,16 +1913,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_table_names_by_filter(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_table_names_by_filter(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_table_names_by_filter_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -1929,16 +1954,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_table(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_table(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_table_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -1967,16 +1993,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_table_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_table_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_table_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -2005,16 +2032,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_table_with_cascade(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_table_with_cascade(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_table_with_cascade_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -2037,16 +2065,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2075,16 +2104,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_partition_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_partition_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_partition_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2111,16 +2141,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_partitions(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_partitions(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_partitions_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2147,16 +2178,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_partitions_pspec(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_partitions_pspec(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_partitions_pspec_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2187,16 +2219,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_append_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_append_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = append_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2223,16 +2256,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_partitions_req(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_partitions_req(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_partitions_req_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2265,16 +2299,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_append_partition_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_append_partition_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = append_partition_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2305,16 +2340,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_append_partition_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_append_partition_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = append_partition_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2347,16 +2383,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_append_partition_by_name_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_append_partition_by_name_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = append_partition_by_name_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2389,16 +2426,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2431,16 +2469,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_partition_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_partition_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_partition_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2471,16 +2510,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_partition_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_partition_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_partition_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2513,16 +2553,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_partition_by_name_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_partition_by_name_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_partition_by_name_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2547,16 +2588,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_partitions_req(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_partitions_req(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_partitions_req_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2585,16 +2627,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2627,16 +2670,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_exchange_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_exchange_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = exchange_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2673,16 +2717,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition_with_auth(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition_with_auth(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_with_auth_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2711,16 +2756,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2749,16 +2795,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2791,16 +2838,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_with_auth(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_with_auth(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_with_auth_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2829,16 +2877,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_pspec(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_pspec(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_pspec_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2867,16 +2916,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition_names(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition_names(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_names_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o2 is not None:
@@ -2905,16 +2955,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_ps(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_ps(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_ps_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2949,16 +3000,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_ps_with_auth(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_ps_with_auth(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_ps_with_auth_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -2989,16 +3041,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition_names_ps(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition_names_ps(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_names_ps_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3029,16 +3082,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_by_filter(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_by_filter(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_by_filter_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3069,16 +3123,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_part_specs_by_filter(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_part_specs_by_filter(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_part_specs_by_filter_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3103,16 +3158,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_by_expr(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_by_expr(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_by_expr_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3141,16 +3197,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_by_names(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_by_names(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_by_names_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3179,16 +3236,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3215,16 +3273,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_partitions(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_partitions(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_partitions_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3253,16 +3312,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_partition_with_environment_context(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_partition_with_environment_context(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_partition_with_environment_context_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3291,16 +3351,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_rename_partition(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_rename_partition(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = rename_partition_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3325,16 +3386,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_partition_name_has_valid_characters(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_partition_name_has_valid_characters(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = partition_name_has_valid_characters_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3359,16 +3421,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_config_value(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_config_value(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_config_value_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3391,16 +3454,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_partition_name_to_vals(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_partition_name_to_vals(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = partition_name_to_vals_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3423,16 +3487,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_partition_name_to_spec(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_partition_name_to_spec(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = partition_name_to_spec_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3461,16 +3526,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_markPartitionForEvent(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_markPartitionForEvent(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = markPartitionForEvent_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3507,16 +3573,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_isPartitionMarkedForEvent(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_isPartitionMarkedForEvent(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = isPartitionMarkedForEvent_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3551,16 +3618,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_add_index(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_add_index(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = add_index_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3593,16 +3661,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_index(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_index(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_index_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -3631,16 +3700,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_index_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_index_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_index_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3669,16 +3739,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_index_by_name(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_index_by_name(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_index_by_name_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3707,16 +3778,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_indexes(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_indexes(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_indexes_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3745,16 +3817,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_index_names(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_index_names(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_index_names_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o2 is not None:
@@ -3777,16 +3850,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_update_table_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_update_table_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = update_table_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3815,16 +3889,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_update_partition_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_update_partition_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = update_partition_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3857,16 +3932,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_table_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_table_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_table_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3901,16 +3977,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partition_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partition_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partition_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3939,16 +4016,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_table_statistics_req(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_table_statistics_req(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_table_statistics_req_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -3973,16 +4051,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_partitions_statistics_req(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_partitions_statistics_req(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_partitions_statistics_req_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4007,16 +4086,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_aggr_stats_for(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_aggr_stats_for(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_aggr_stats_for_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4041,16 +4121,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_set_aggr_stats_for(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_set_aggr_stats_for(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = set_aggr_stats_for_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4085,16 +4166,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_delete_partition_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_delete_partition_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = delete_partition_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4127,16 +4209,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_delete_table_column_statistics(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_delete_table_column_statistics(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = delete_table_column_statistics_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4165,16 +4248,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_function(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_function(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_function_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -4203,16 +4287,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_function(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_function(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_function_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o3 is not None:
@@ -4239,16 +4324,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_alter_function(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_alter_function(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = alter_function_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.o1 is not None:
       raise result.o1
     if result.o2 is not None:
@@ -4273,16 +4359,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_functions(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_functions(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_functions_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4307,16 +4394,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_function(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_function(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_function_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4341,16 +4429,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_create_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_create_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = create_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4373,43 +4462,45 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_drop_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_drop_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = drop_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
       raise result.o1
     raise TApplicationException(TApplicationException.MISSING_RESULT, "drop_role failed: unknown result");
 
-  def get_role_names(self, ):
+  def get_role_names(self):
     self.send_get_role_names()
     return self.recv_get_role_names()
 
-  def send_get_role_names(self, ):
+  def send_get_role_names(self):
     self._oprot.writeMessageBegin('get_role_names', TMessageType.CALL, self._seqid)
     args = get_role_names_args()
     args.write(self._oprot)
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_role_names(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_role_names(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_role_names_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4442,16 +4533,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_grant_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_grant_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = grant_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4478,16 +4570,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_revoke_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_revoke_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = revoke_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4512,16 +4605,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_list_roles(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_list_roles(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = list_roles_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4544,16 +4638,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_grant_revoke_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_grant_revoke_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = grant_revoke_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4576,16 +4671,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_principals_in_role(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_principals_in_role(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_principals_in_role_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4608,16 +4704,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_role_grants_for_principal(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_role_grants_for_principal(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_role_grants_for_principal_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4644,16 +4741,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_privilege_set(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_privilege_set(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_privilege_set_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4680,16 +4778,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_list_privileges(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_list_privileges(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = list_privileges_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4712,16 +4811,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_grant_privileges(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_grant_privileges(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = grant_privileges_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4744,16 +4844,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_revoke_privileges(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_revoke_privileges(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = revoke_privileges_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4776,16 +4877,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_grant_revoke_privileges(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_grant_revoke_privileges(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = grant_revoke_privileges_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4810,16 +4912,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_set_ugi(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_set_ugi(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = set_ugi_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4844,16 +4947,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_get_delegation_token(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_get_delegation_token(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = get_delegation_token_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4876,16 +4980,17 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_renew_delegation_token(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_renew_delegation_token(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = renew_delegation_token_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     if result.o1 is not None:
@@ -4908,66 +5013,69 @@ class Client(fb303.FacebookService.Client, Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_cancel_delegation_token(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_cancel_delegation_token(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EX

<TRUNCATED>

[08/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIService.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIService.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIService.java
index 54851b8..4e57581 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIService.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIService.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,12 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
 public class TCLIService {
 
   public interface Iface {
@@ -77,43 +81,43 @@ public class TCLIService {
 
   public interface AsyncIface {
 
-    public void OpenSession(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.OpenSession_call> resultHandler) throws org.apache.thrift.TException;
+    public void OpenSession(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void CloseSession(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.CloseSession_call> resultHandler) throws org.apache.thrift.TException;
+    public void CloseSession(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetInfo(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetInfo_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetInfo(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void ExecuteStatement(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.ExecuteStatement_call> resultHandler) throws org.apache.thrift.TException;
+    public void ExecuteStatement(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetTypeInfo(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetTypeInfo_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetTypeInfo(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetCatalogs(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetCatalogs_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetCatalogs(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetSchemas(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetSchemas_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetSchemas(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetTables(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetTables_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetTables(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetTableTypes(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetTableTypes_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetTableTypes(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetColumns(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetColumns_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetColumns(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetFunctions(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetFunctions_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetFunctions(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetOperationStatus(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetOperationStatus_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetOperationStatus(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void CancelOperation(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.CancelOperation_call> resultHandler) throws org.apache.thrift.TException;
+    public void CancelOperation(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void CloseOperation(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.CloseOperation_call> resultHandler) throws org.apache.thrift.TException;
+    public void CloseOperation(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetResultSetMetadata(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetResultSetMetadata_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetResultSetMetadata(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void FetchResults(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.FetchResults_call> resultHandler) throws org.apache.thrift.TException;
+    public void FetchResults(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void GetDelegationToken(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.GetDelegationToken_call> resultHandler) throws org.apache.thrift.TException;
+    public void GetDelegationToken(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void CancelDelegationToken(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.CancelDelegationToken_call> resultHandler) throws org.apache.thrift.TException;
+    public void CancelDelegationToken(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void RenewDelegationToken(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.RenewDelegationToken_call> resultHandler) throws org.apache.thrift.TException;
+    public void RenewDelegationToken(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
   }
 
@@ -592,7 +596,7 @@ public class TCLIService {
       super(protocolFactory, clientManager, transport);
     }
 
-    public void OpenSession(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback<OpenSession_call> resultHandler) throws org.apache.thrift.TException {
+    public void OpenSession(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       OpenSession_call method_call = new OpenSession_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -601,7 +605,7 @@ public class TCLIService {
 
     public static class OpenSession_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TOpenSessionReq req;
-      public OpenSession_call(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback<OpenSession_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public OpenSession_call(TOpenSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -624,7 +628,7 @@ public class TCLIService {
       }
     }
 
-    public void CloseSession(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback<CloseSession_call> resultHandler) throws org.apache.thrift.TException {
+    public void CloseSession(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       CloseSession_call method_call = new CloseSession_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -633,7 +637,7 @@ public class TCLIService {
 
     public static class CloseSession_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TCloseSessionReq req;
-      public CloseSession_call(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback<CloseSession_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public CloseSession_call(TCloseSessionReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -656,7 +660,7 @@ public class TCLIService {
       }
     }
 
-    public void GetInfo(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback<GetInfo_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetInfo(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetInfo_call method_call = new GetInfo_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -665,7 +669,7 @@ public class TCLIService {
 
     public static class GetInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetInfoReq req;
-      public GetInfo_call(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback<GetInfo_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetInfo_call(TGetInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -688,7 +692,7 @@ public class TCLIService {
       }
     }
 
-    public void ExecuteStatement(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback<ExecuteStatement_call> resultHandler) throws org.apache.thrift.TException {
+    public void ExecuteStatement(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       ExecuteStatement_call method_call = new ExecuteStatement_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -697,7 +701,7 @@ public class TCLIService {
 
     public static class ExecuteStatement_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TExecuteStatementReq req;
-      public ExecuteStatement_call(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback<ExecuteStatement_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public ExecuteStatement_call(TExecuteStatementReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -720,7 +724,7 @@ public class TCLIService {
       }
     }
 
-    public void GetTypeInfo(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback<GetTypeInfo_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetTypeInfo(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetTypeInfo_call method_call = new GetTypeInfo_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -729,7 +733,7 @@ public class TCLIService {
 
     public static class GetTypeInfo_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetTypeInfoReq req;
-      public GetTypeInfo_call(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback<GetTypeInfo_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetTypeInfo_call(TGetTypeInfoReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -752,7 +756,7 @@ public class TCLIService {
       }
     }
 
-    public void GetCatalogs(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback<GetCatalogs_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetCatalogs(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetCatalogs_call method_call = new GetCatalogs_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -761,7 +765,7 @@ public class TCLIService {
 
     public static class GetCatalogs_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetCatalogsReq req;
-      public GetCatalogs_call(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback<GetCatalogs_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetCatalogs_call(TGetCatalogsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -784,7 +788,7 @@ public class TCLIService {
       }
     }
 
-    public void GetSchemas(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback<GetSchemas_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetSchemas(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetSchemas_call method_call = new GetSchemas_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -793,7 +797,7 @@ public class TCLIService {
 
     public static class GetSchemas_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetSchemasReq req;
-      public GetSchemas_call(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback<GetSchemas_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetSchemas_call(TGetSchemasReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -816,7 +820,7 @@ public class TCLIService {
       }
     }
 
-    public void GetTables(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback<GetTables_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetTables(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetTables_call method_call = new GetTables_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -825,7 +829,7 @@ public class TCLIService {
 
     public static class GetTables_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetTablesReq req;
-      public GetTables_call(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback<GetTables_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetTables_call(TGetTablesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -848,7 +852,7 @@ public class TCLIService {
       }
     }
 
-    public void GetTableTypes(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback<GetTableTypes_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetTableTypes(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetTableTypes_call method_call = new GetTableTypes_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -857,7 +861,7 @@ public class TCLIService {
 
     public static class GetTableTypes_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetTableTypesReq req;
-      public GetTableTypes_call(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback<GetTableTypes_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetTableTypes_call(TGetTableTypesReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -880,7 +884,7 @@ public class TCLIService {
       }
     }
 
-    public void GetColumns(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback<GetColumns_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetColumns(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetColumns_call method_call = new GetColumns_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -889,7 +893,7 @@ public class TCLIService {
 
     public static class GetColumns_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetColumnsReq req;
-      public GetColumns_call(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback<GetColumns_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetColumns_call(TGetColumnsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -912,7 +916,7 @@ public class TCLIService {
       }
     }
 
-    public void GetFunctions(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback<GetFunctions_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetFunctions(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetFunctions_call method_call = new GetFunctions_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -921,7 +925,7 @@ public class TCLIService {
 
     public static class GetFunctions_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetFunctionsReq req;
-      public GetFunctions_call(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback<GetFunctions_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetFunctions_call(TGetFunctionsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -944,7 +948,7 @@ public class TCLIService {
       }
     }
 
-    public void GetOperationStatus(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback<GetOperationStatus_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetOperationStatus(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetOperationStatus_call method_call = new GetOperationStatus_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -953,7 +957,7 @@ public class TCLIService {
 
     public static class GetOperationStatus_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetOperationStatusReq req;
-      public GetOperationStatus_call(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback<GetOperationStatus_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetOperationStatus_call(TGetOperationStatusReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -976,7 +980,7 @@ public class TCLIService {
       }
     }
 
-    public void CancelOperation(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback<CancelOperation_call> resultHandler) throws org.apache.thrift.TException {
+    public void CancelOperation(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       CancelOperation_call method_call = new CancelOperation_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -985,7 +989,7 @@ public class TCLIService {
 
     public static class CancelOperation_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TCancelOperationReq req;
-      public CancelOperation_call(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback<CancelOperation_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public CancelOperation_call(TCancelOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1008,7 +1012,7 @@ public class TCLIService {
       }
     }
 
-    public void CloseOperation(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback<CloseOperation_call> resultHandler) throws org.apache.thrift.TException {
+    public void CloseOperation(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       CloseOperation_call method_call = new CloseOperation_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1017,7 +1021,7 @@ public class TCLIService {
 
     public static class CloseOperation_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TCloseOperationReq req;
-      public CloseOperation_call(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback<CloseOperation_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public CloseOperation_call(TCloseOperationReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1040,7 +1044,7 @@ public class TCLIService {
       }
     }
 
-    public void GetResultSetMetadata(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback<GetResultSetMetadata_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetResultSetMetadata(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetResultSetMetadata_call method_call = new GetResultSetMetadata_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1049,7 +1053,7 @@ public class TCLIService {
 
     public static class GetResultSetMetadata_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetResultSetMetadataReq req;
-      public GetResultSetMetadata_call(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback<GetResultSetMetadata_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetResultSetMetadata_call(TGetResultSetMetadataReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1072,7 +1076,7 @@ public class TCLIService {
       }
     }
 
-    public void FetchResults(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback<FetchResults_call> resultHandler) throws org.apache.thrift.TException {
+    public void FetchResults(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       FetchResults_call method_call = new FetchResults_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1081,7 +1085,7 @@ public class TCLIService {
 
     public static class FetchResults_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TFetchResultsReq req;
-      public FetchResults_call(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback<FetchResults_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public FetchResults_call(TFetchResultsReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1104,7 +1108,7 @@ public class TCLIService {
       }
     }
 
-    public void GetDelegationToken(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<GetDelegationToken_call> resultHandler) throws org.apache.thrift.TException {
+    public void GetDelegationToken(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       GetDelegationToken_call method_call = new GetDelegationToken_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1113,7 +1117,7 @@ public class TCLIService {
 
     public static class GetDelegationToken_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TGetDelegationTokenReq req;
-      public GetDelegationToken_call(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<GetDelegationToken_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public GetDelegationToken_call(TGetDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1136,7 +1140,7 @@ public class TCLIService {
       }
     }
 
-    public void CancelDelegationToken(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<CancelDelegationToken_call> resultHandler) throws org.apache.thrift.TException {
+    public void CancelDelegationToken(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       CancelDelegationToken_call method_call = new CancelDelegationToken_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1145,7 +1149,7 @@ public class TCLIService {
 
     public static class CancelDelegationToken_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TCancelDelegationTokenReq req;
-      public CancelDelegationToken_call(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<CancelDelegationToken_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public CancelDelegationToken_call(TCancelDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1168,7 +1172,7 @@ public class TCLIService {
       }
     }
 
-    public void RenewDelegationToken(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<RenewDelegationToken_call> resultHandler) throws org.apache.thrift.TException {
+    public void RenewDelegationToken(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       RenewDelegationToken_call method_call = new RenewDelegationToken_call(req, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -1177,7 +1181,7 @@ public class TCLIService {
 
     public static class RenewDelegationToken_call extends org.apache.thrift.async.TAsyncMethodCall {
       private TRenewDelegationTokenReq req;
-      public RenewDelegationToken_call(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback<RenewDelegationToken_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public RenewDelegationToken_call(TRenewDelegationTokenReq req, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.req = req;
       }
@@ -1617,7 +1621,1011 @@ public class TCLIService {
 
   }
 
-  public static class OpenSession_args implements org.apache.thrift.TBase<OpenSession_args, OpenSession_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class AsyncProcessor<I extends AsyncIface> extends org.apache.thrift.TBaseAsyncProcessor<I> {
+    private static final Logger LOGGER = LoggerFactory.getLogger(AsyncProcessor.class.getName());
+    public AsyncProcessor(I iface) {
+      super(iface, getProcessMap(new HashMap<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase, ?>>()));
+    }
+
+    protected AsyncProcessor(I iface, Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase, ?>> processMap) {
+      super(iface, getProcessMap(processMap));
+    }
+
+    private static <I extends AsyncIface> Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase,?>> getProcessMap(Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase, ?>> processMap) {
+      processMap.put("OpenSession", new OpenSession());
+      processMap.put("CloseSession", new CloseSession());
+      processMap.put("GetInfo", new GetInfo());
+      processMap.put("ExecuteStatement", new ExecuteStatement());
+      processMap.put("GetTypeInfo", new GetTypeInfo());
+      processMap.put("GetCatalogs", new GetCatalogs());
+      processMap.put("GetSchemas", new GetSchemas());
+      processMap.put("GetTables", new GetTables());
+      processMap.put("GetTableTypes", new GetTableTypes());
+      processMap.put("GetColumns", new GetColumns());
+      processMap.put("GetFunctions", new GetFunctions());
+      processMap.put("GetOperationStatus", new GetOperationStatus());
+      processMap.put("CancelOperation", new CancelOperation());
+      processMap.put("CloseOperation", new CloseOperation());
+      processMap.put("GetResultSetMetadata", new GetResultSetMetadata());
+      processMap.put("FetchResults", new FetchResults());
+      processMap.put("GetDelegationToken", new GetDelegationToken());
+      processMap.put("CancelDelegationToken", new CancelDelegationToken());
+      processMap.put("RenewDelegationToken", new RenewDelegationToken());
+      return processMap;
+    }
+
+    public static class OpenSession<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, OpenSession_args, TOpenSessionResp> {
+      public OpenSession() {
+        super("OpenSession");
+      }
+
+      public OpenSession_args getEmptyArgsInstance() {
+        return new OpenSession_args();
+      }
+
+      public AsyncMethodCallback<TOpenSessionResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TOpenSessionResp>() { 
+          public void onComplete(TOpenSessionResp o) {
+            OpenSession_result result = new OpenSession_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            OpenSession_result result = new OpenSession_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, OpenSession_args args, org.apache.thrift.async.AsyncMethodCallback<TOpenSessionResp> resultHandler) throws TException {
+        iface.OpenSession(args.req,resultHandler);
+      }
+    }
+
+    public static class CloseSession<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, CloseSession_args, TCloseSessionResp> {
+      public CloseSession() {
+        super("CloseSession");
+      }
+
+      public CloseSession_args getEmptyArgsInstance() {
+        return new CloseSession_args();
+      }
+
+      public AsyncMethodCallback<TCloseSessionResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TCloseSessionResp>() { 
+          public void onComplete(TCloseSessionResp o) {
+            CloseSession_result result = new CloseSession_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            CloseSession_result result = new CloseSession_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, CloseSession_args args, org.apache.thrift.async.AsyncMethodCallback<TCloseSessionResp> resultHandler) throws TException {
+        iface.CloseSession(args.req,resultHandler);
+      }
+    }
+
+    public static class GetInfo<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetInfo_args, TGetInfoResp> {
+      public GetInfo() {
+        super("GetInfo");
+      }
+
+      public GetInfo_args getEmptyArgsInstance() {
+        return new GetInfo_args();
+      }
+
+      public AsyncMethodCallback<TGetInfoResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetInfoResp>() { 
+          public void onComplete(TGetInfoResp o) {
+            GetInfo_result result = new GetInfo_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetInfo_result result = new GetInfo_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetInfo_args args, org.apache.thrift.async.AsyncMethodCallback<TGetInfoResp> resultHandler) throws TException {
+        iface.GetInfo(args.req,resultHandler);
+      }
+    }
+
+    public static class ExecuteStatement<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, ExecuteStatement_args, TExecuteStatementResp> {
+      public ExecuteStatement() {
+        super("ExecuteStatement");
+      }
+
+      public ExecuteStatement_args getEmptyArgsInstance() {
+        return new ExecuteStatement_args();
+      }
+
+      public AsyncMethodCallback<TExecuteStatementResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TExecuteStatementResp>() { 
+          public void onComplete(TExecuteStatementResp o) {
+            ExecuteStatement_result result = new ExecuteStatement_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            ExecuteStatement_result result = new ExecuteStatement_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, ExecuteStatement_args args, org.apache.thrift.async.AsyncMethodCallback<TExecuteStatementResp> resultHandler) throws TException {
+        iface.ExecuteStatement(args.req,resultHandler);
+      }
+    }
+
+    public static class GetTypeInfo<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetTypeInfo_args, TGetTypeInfoResp> {
+      public GetTypeInfo() {
+        super("GetTypeInfo");
+      }
+
+      public GetTypeInfo_args getEmptyArgsInstance() {
+        return new GetTypeInfo_args();
+      }
+
+      public AsyncMethodCallback<TGetTypeInfoResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetTypeInfoResp>() { 
+          public void onComplete(TGetTypeInfoResp o) {
+            GetTypeInfo_result result = new GetTypeInfo_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetTypeInfo_result result = new GetTypeInfo_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetTypeInfo_args args, org.apache.thrift.async.AsyncMethodCallback<TGetTypeInfoResp> resultHandler) throws TException {
+        iface.GetTypeInfo(args.req,resultHandler);
+      }
+    }
+
+    public static class GetCatalogs<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetCatalogs_args, TGetCatalogsResp> {
+      public GetCatalogs() {
+        super("GetCatalogs");
+      }
+
+      public GetCatalogs_args getEmptyArgsInstance() {
+        return new GetCatalogs_args();
+      }
+
+      public AsyncMethodCallback<TGetCatalogsResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetCatalogsResp>() { 
+          public void onComplete(TGetCatalogsResp o) {
+            GetCatalogs_result result = new GetCatalogs_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetCatalogs_result result = new GetCatalogs_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetCatalogs_args args, org.apache.thrift.async.AsyncMethodCallback<TGetCatalogsResp> resultHandler) throws TException {
+        iface.GetCatalogs(args.req,resultHandler);
+      }
+    }
+
+    public static class GetSchemas<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetSchemas_args, TGetSchemasResp> {
+      public GetSchemas() {
+        super("GetSchemas");
+      }
+
+      public GetSchemas_args getEmptyArgsInstance() {
+        return new GetSchemas_args();
+      }
+
+      public AsyncMethodCallback<TGetSchemasResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetSchemasResp>() { 
+          public void onComplete(TGetSchemasResp o) {
+            GetSchemas_result result = new GetSchemas_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetSchemas_result result = new GetSchemas_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetSchemas_args args, org.apache.thrift.async.AsyncMethodCallback<TGetSchemasResp> resultHandler) throws TException {
+        iface.GetSchemas(args.req,resultHandler);
+      }
+    }
+
+    public static class GetTables<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetTables_args, TGetTablesResp> {
+      public GetTables() {
+        super("GetTables");
+      }
+
+      public GetTables_args getEmptyArgsInstance() {
+        return new GetTables_args();
+      }
+
+      public AsyncMethodCallback<TGetTablesResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetTablesResp>() { 
+          public void onComplete(TGetTablesResp o) {
+            GetTables_result result = new GetTables_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetTables_result result = new GetTables_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetTables_args args, org.apache.thrift.async.AsyncMethodCallback<TGetTablesResp> resultHandler) throws TException {
+        iface.GetTables(args.req,resultHandler);
+      }
+    }
+
+    public static class GetTableTypes<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetTableTypes_args, TGetTableTypesResp> {
+      public GetTableTypes() {
+        super("GetTableTypes");
+      }
+
+      public GetTableTypes_args getEmptyArgsInstance() {
+        return new GetTableTypes_args();
+      }
+
+      public AsyncMethodCallback<TGetTableTypesResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetTableTypesResp>() { 
+          public void onComplete(TGetTableTypesResp o) {
+            GetTableTypes_result result = new GetTableTypes_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetTableTypes_result result = new GetTableTypes_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetTableTypes_args args, org.apache.thrift.async.AsyncMethodCallback<TGetTableTypesResp> resultHandler) throws TException {
+        iface.GetTableTypes(args.req,resultHandler);
+      }
+    }
+
+    public static class GetColumns<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetColumns_args, TGetColumnsResp> {
+      public GetColumns() {
+        super("GetColumns");
+      }
+
+      public GetColumns_args getEmptyArgsInstance() {
+        return new GetColumns_args();
+      }
+
+      public AsyncMethodCallback<TGetColumnsResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetColumnsResp>() { 
+          public void onComplete(TGetColumnsResp o) {
+            GetColumns_result result = new GetColumns_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetColumns_result result = new GetColumns_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetColumns_args args, org.apache.thrift.async.AsyncMethodCallback<TGetColumnsResp> resultHandler) throws TException {
+        iface.GetColumns(args.req,resultHandler);
+      }
+    }
+
+    public static class GetFunctions<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetFunctions_args, TGetFunctionsResp> {
+      public GetFunctions() {
+        super("GetFunctions");
+      }
+
+      public GetFunctions_args getEmptyArgsInstance() {
+        return new GetFunctions_args();
+      }
+
+      public AsyncMethodCallback<TGetFunctionsResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetFunctionsResp>() { 
+          public void onComplete(TGetFunctionsResp o) {
+            GetFunctions_result result = new GetFunctions_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetFunctions_result result = new GetFunctions_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetFunctions_args args, org.apache.thrift.async.AsyncMethodCallback<TGetFunctionsResp> resultHandler) throws TException {
+        iface.GetFunctions(args.req,resultHandler);
+      }
+    }
+
+    public static class GetOperationStatus<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetOperationStatus_args, TGetOperationStatusResp> {
+      public GetOperationStatus() {
+        super("GetOperationStatus");
+      }
+
+      public GetOperationStatus_args getEmptyArgsInstance() {
+        return new GetOperationStatus_args();
+      }
+
+      public AsyncMethodCallback<TGetOperationStatusResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetOperationStatusResp>() { 
+          public void onComplete(TGetOperationStatusResp o) {
+            GetOperationStatus_result result = new GetOperationStatus_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetOperationStatus_result result = new GetOperationStatus_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetOperationStatus_args args, org.apache.thrift.async.AsyncMethodCallback<TGetOperationStatusResp> resultHandler) throws TException {
+        iface.GetOperationStatus(args.req,resultHandler);
+      }
+    }
+
+    public static class CancelOperation<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, CancelOperation_args, TCancelOperationResp> {
+      public CancelOperation() {
+        super("CancelOperation");
+      }
+
+      public CancelOperation_args getEmptyArgsInstance() {
+        return new CancelOperation_args();
+      }
+
+      public AsyncMethodCallback<TCancelOperationResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TCancelOperationResp>() { 
+          public void onComplete(TCancelOperationResp o) {
+            CancelOperation_result result = new CancelOperation_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            CancelOperation_result result = new CancelOperation_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, CancelOperation_args args, org.apache.thrift.async.AsyncMethodCallback<TCancelOperationResp> resultHandler) throws TException {
+        iface.CancelOperation(args.req,resultHandler);
+      }
+    }
+
+    public static class CloseOperation<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, CloseOperation_args, TCloseOperationResp> {
+      public CloseOperation() {
+        super("CloseOperation");
+      }
+
+      public CloseOperation_args getEmptyArgsInstance() {
+        return new CloseOperation_args();
+      }
+
+      public AsyncMethodCallback<TCloseOperationResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TCloseOperationResp>() { 
+          public void onComplete(TCloseOperationResp o) {
+            CloseOperation_result result = new CloseOperation_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            CloseOperation_result result = new CloseOperation_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, CloseOperation_args args, org.apache.thrift.async.AsyncMethodCallback<TCloseOperationResp> resultHandler) throws TException {
+        iface.CloseOperation(args.req,resultHandler);
+      }
+    }
+
+    public static class GetResultSetMetadata<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetResultSetMetadata_args, TGetResultSetMetadataResp> {
+      public GetResultSetMetadata() {
+        super("GetResultSetMetadata");
+      }
+
+      public GetResultSetMetadata_args getEmptyArgsInstance() {
+        return new GetResultSetMetadata_args();
+      }
+
+      public AsyncMethodCallback<TGetResultSetMetadataResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetResultSetMetadataResp>() { 
+          public void onComplete(TGetResultSetMetadataResp o) {
+            GetResultSetMetadata_result result = new GetResultSetMetadata_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetResultSetMetadata_result result = new GetResultSetMetadata_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetResultSetMetadata_args args, org.apache.thrift.async.AsyncMethodCallback<TGetResultSetMetadataResp> resultHandler) throws TException {
+        iface.GetResultSetMetadata(args.req,resultHandler);
+      }
+    }
+
+    public static class FetchResults<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, FetchResults_args, TFetchResultsResp> {
+      public FetchResults() {
+        super("FetchResults");
+      }
+
+      public FetchResults_args getEmptyArgsInstance() {
+        return new FetchResults_args();
+      }
+
+      public AsyncMethodCallback<TFetchResultsResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TFetchResultsResp>() { 
+          public void onComplete(TFetchResultsResp o) {
+            FetchResults_result result = new FetchResults_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            FetchResults_result result = new FetchResults_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, FetchResults_args args, org.apache.thrift.async.AsyncMethodCallback<TFetchResultsResp> resultHandler) throws TException {
+        iface.FetchResults(args.req,resultHandler);
+      }
+    }
+
+    public static class GetDelegationToken<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, GetDelegationToken_args, TGetDelegationTokenResp> {
+      public GetDelegationToken() {
+        super("GetDelegationToken");
+      }
+
+      public GetDelegationToken_args getEmptyArgsInstance() {
+        return new GetDelegationToken_args();
+      }
+
+      public AsyncMethodCallback<TGetDelegationTokenResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TGetDelegationTokenResp>() { 
+          public void onComplete(TGetDelegationTokenResp o) {
+            GetDelegationToken_result result = new GetDelegationToken_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            GetDelegationToken_result result = new GetDelegationToken_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, GetDelegationToken_args args, org.apache.thrift.async.AsyncMethodCallback<TGetDelegationTokenResp> resultHandler) throws TException {
+        iface.GetDelegationToken(args.req,resultHandler);
+      }
+    }
+
+    public static class CancelDelegationToken<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, CancelDelegationToken_args, TCancelDelegationTokenResp> {
+      public CancelDelegationToken() {
+        super("CancelDelegationToken");
+      }
+
+      public CancelDelegationToken_args getEmptyArgsInstance() {
+        return new CancelDelegationToken_args();
+      }
+
+      public AsyncMethodCallback<TCancelDelegationTokenResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TCancelDelegationTokenResp>() { 
+          public void onComplete(TCancelDelegationTokenResp o) {
+            CancelDelegationToken_result result = new CancelDelegationToken_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            CancelDelegationToken_result result = new CancelDelegationToken_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, CancelDelegationToken_args args, org.apache.thrift.async.AsyncMethodCallback<TCancelDelegationTokenResp> resultHandler) throws TException {
+        iface.CancelDelegationToken(args.req,resultHandler);
+      }
+    }
+
+    public static class RenewDelegationToken<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, RenewDelegationToken_args, TRenewDelegationTokenResp> {
+      public RenewDelegationToken() {
+        super("RenewDelegationToken");
+      }
+
+      public RenewDelegationToken_args getEmptyArgsInstance() {
+        return new RenewDelegationToken_args();
+      }
+
+      public AsyncMethodCallback<TRenewDelegationTokenResp> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<TRenewDelegationTokenResp>() { 
+          public void onComplete(TRenewDelegationTokenResp o) {
+            RenewDelegationToken_result result = new RenewDelegationToken_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            RenewDelegationToken_result result = new RenewDelegationToken_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, RenewDelegationToken_args args, org.apache.thrift.async.AsyncMethodCallback<TRenewDelegationTokenResp> resultHandler) throws TException {
+        iface.RenewDelegationToken(args.req,resultHandler);
+      }
+    }
+
+  }
+
+  public static class OpenSession_args implements org.apache.thrift.TBase<OpenSession_args, OpenSession_args._Fields>, java.io.Serializable, Cloneable, Comparable<OpenSession_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("OpenSession_args");
 
     private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -1811,30 +2819,30 @@ public class TCLIService {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_req = true && (isSetReq());
-      builder.append(present_req);
+      list.add(present_req);
       if (present_req)
-        builder.append(req);
+        list.add(req);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(OpenSession_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      OpenSession_args typedOther = (OpenSession_args)other;
 
-      lastComparison = Boolean.valueOf(isSetReq()).compareTo(typedOther.isSetReq());
+      lastComparison = Boolean.valueOf(isSetReq()).compareTo(other.isSetReq());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetReq()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.req, typedOther.req);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.req, other.req);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -1980,7 +2988,7 @@ public class TCLIService {
 
   }
 
-  public static class OpenSession_result implements org.apache.thrift.TBase<OpenSession_result, OpenSession_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class OpenSession_result implements org.apache.thrift.TBase<OpenSession_result, OpenSession_result._Fields>, java.io.Serializable, Cloneable, Comparable<OpenSession_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("OpenSession_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -2174,30 +3182,30 @@ public class TCLIService {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(OpenSession_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      OpenSession_result typedOther = (OpenSession_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -2343,7 +3351,7 @@ public class TCLIService {
 
   }
 
-  public static class CloseSession_args implements org.apache.thrift.TBase<CloseSession_args, CloseSession_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class CloseSession_args implements org.apache.thrift.TBase<CloseSession_args, CloseSession_args._Fields>, java.io.Serializable, Cloneable, Comparable<CloseSession_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CloseSession_args");
 
     private static final org.apache.thrift.protocol.TField REQ_FIELD_DESC = new org.apache.thrift.protocol.TField("req", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -2537,30 +3545,30 @@ public class TCLIService {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_req = true && (isSetReq());
-      builder.append(present_req);
+      list.add(present_req);
       if (present_req)
-        builder.append(req);
+        list.add(req);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(CloseSession_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      CloseSession_args typedOther = (CloseSession_args)other;
 
-      lastComparison = Boolean.valueOf(isSetReq()).compareTo(typedOther.isSetReq());
+      lastComparison = Boolean.valueOf(isSetReq()).compareTo(other.isSetReq());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetReq()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.req, typedOther.req);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.req, other.req);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -2706,7 +3714,7 @@ public class TCLIService {
 
   }
 
-  public static class CloseSession_result implements org.apache.thrift.TBase<CloseSession_result, CloseSession_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class CloseSession_result implements org.apache.thrift.TBase<CloseSession_result, CloseSession_result._Fields>, java.io.Serializable, Cloneable, Comparable<CloseSession_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CloseSession_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -2900,30 +3908,30 @@ public class TCLIService {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(CloseSession_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      CloseSession_result typedOther = (CloseSession_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -3069,7 +4077,7 @@ public class TCLIService {
 
   }
 
-  public static class GetInfo_args implements org.apache.thrift.TBase<GetInfo_args, GetInfo_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class GetInf

<TRUNCATED>

[47/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
index a0b34cb..47dd99d 100644
--- a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -8,6 +8,11 @@
 
 namespace Apache { namespace Hadoop { namespace Hive {
 
+
+ThriftHiveMetastore_getMetaConf_args::~ThriftHiveMetastore_getMetaConf_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_getMetaConf_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -50,6 +55,7 @@ uint32_t ThriftHiveMetastore_getMetaConf_args::read(::apache::thrift::protocol::
 
 uint32_t ThriftHiveMetastore_getMetaConf_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_getMetaConf_args");
 
   xfer += oprot->writeFieldBegin("key", ::apache::thrift::protocol::T_STRING, 1);
@@ -58,11 +64,18 @@ uint32_t ThriftHiveMetastore_getMetaConf_args::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_getMetaConf_pargs::~ThriftHiveMetastore_getMetaConf_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_getMetaConf_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_getMetaConf_pargs");
 
   xfer += oprot->writeFieldBegin("key", ::apache::thrift::protocol::T_STRING, 1);
@@ -71,9 +84,15 @@ uint32_t ThriftHiveMetastore_getMetaConf_pargs::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_getMetaConf_result::~ThriftHiveMetastore_getMetaConf_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_getMetaConf_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -142,6 +161,11 @@ uint32_t ThriftHiveMetastore_getMetaConf_result::write(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_getMetaConf_presult::~ThriftHiveMetastore_getMetaConf_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_getMetaConf_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -190,6 +214,11 @@ uint32_t ThriftHiveMetastore_getMetaConf_presult::read(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_setMetaConf_args::~ThriftHiveMetastore_setMetaConf_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_setMetaConf_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -240,6 +269,7 @@ uint32_t ThriftHiveMetastore_setMetaConf_args::read(::apache::thrift::protocol::
 
 uint32_t ThriftHiveMetastore_setMetaConf_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_setMetaConf_args");
 
   xfer += oprot->writeFieldBegin("key", ::apache::thrift::protocol::T_STRING, 1);
@@ -252,11 +282,18 @@ uint32_t ThriftHiveMetastore_setMetaConf_args::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_setMetaConf_pargs::~ThriftHiveMetastore_setMetaConf_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_setMetaConf_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_setMetaConf_pargs");
 
   xfer += oprot->writeFieldBegin("key", ::apache::thrift::protocol::T_STRING, 1);
@@ -269,9 +306,15 @@ uint32_t ThriftHiveMetastore_setMetaConf_pargs::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_setMetaConf_result::~ThriftHiveMetastore_setMetaConf_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_setMetaConf_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -328,6 +371,11 @@ uint32_t ThriftHiveMetastore_setMetaConf_result::write(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_setMetaConf_presult::~ThriftHiveMetastore_setMetaConf_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_setMetaConf_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -368,6 +416,11 @@ uint32_t ThriftHiveMetastore_setMetaConf_presult::read(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_database_args::~ThriftHiveMetastore_create_database_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_database_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -410,6 +463,7 @@ uint32_t ThriftHiveMetastore_create_database_args::read(::apache::thrift::protoc
 
 uint32_t ThriftHiveMetastore_create_database_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_database_args");
 
   xfer += oprot->writeFieldBegin("database", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -418,11 +472,18 @@ uint32_t ThriftHiveMetastore_create_database_args::write(::apache::thrift::proto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_database_pargs::~ThriftHiveMetastore_create_database_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_database_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_database_pargs");
 
   xfer += oprot->writeFieldBegin("database", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -431,9 +492,15 @@ uint32_t ThriftHiveMetastore_create_database_pargs::write(::apache::thrift::prot
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_database_result::~ThriftHiveMetastore_create_database_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_database_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -514,6 +581,11 @@ uint32_t ThriftHiveMetastore_create_database_result::write(::apache::thrift::pro
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_database_presult::~ThriftHiveMetastore_create_database_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_database_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -570,6 +642,11 @@ uint32_t ThriftHiveMetastore_create_database_presult::read(::apache::thrift::pro
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_database_args::~ThriftHiveMetastore_get_database_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_database_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -612,6 +689,7 @@ uint32_t ThriftHiveMetastore_get_database_args::read(::apache::thrift::protocol:
 
 uint32_t ThriftHiveMetastore_get_database_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_database_args");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -620,11 +698,18 @@ uint32_t ThriftHiveMetastore_get_database_args::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_database_pargs::~ThriftHiveMetastore_get_database_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_database_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_database_pargs");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -633,9 +718,15 @@ uint32_t ThriftHiveMetastore_get_database_pargs::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_database_result::~ThriftHiveMetastore_get_database_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_database_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -716,6 +807,11 @@ uint32_t ThriftHiveMetastore_get_database_result::write(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_database_presult::~ThriftHiveMetastore_get_database_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_database_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -772,6 +868,11 @@ uint32_t ThriftHiveMetastore_get_database_presult::read(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_database_args::~ThriftHiveMetastore_drop_database_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_database_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -830,6 +931,7 @@ uint32_t ThriftHiveMetastore_drop_database_args::read(::apache::thrift::protocol
 
 uint32_t ThriftHiveMetastore_drop_database_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_database_args");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -846,11 +948,18 @@ uint32_t ThriftHiveMetastore_drop_database_args::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_database_pargs::~ThriftHiveMetastore_drop_database_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_database_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_database_pargs");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -867,9 +976,15 @@ uint32_t ThriftHiveMetastore_drop_database_pargs::write(::apache::thrift::protoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_database_result::~ThriftHiveMetastore_drop_database_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_database_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -950,6 +1065,11 @@ uint32_t ThriftHiveMetastore_drop_database_result::write(::apache::thrift::proto
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_database_presult::~ThriftHiveMetastore_drop_database_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_database_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1006,6 +1126,11 @@ uint32_t ThriftHiveMetastore_drop_database_presult::read(::apache::thrift::proto
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_databases_args::~ThriftHiveMetastore_get_databases_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_databases_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1048,6 +1173,7 @@ uint32_t ThriftHiveMetastore_get_databases_args::read(::apache::thrift::protocol
 
 uint32_t ThriftHiveMetastore_get_databases_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_databases_args");
 
   xfer += oprot->writeFieldBegin("pattern", ::apache::thrift::protocol::T_STRING, 1);
@@ -1056,11 +1182,18 @@ uint32_t ThriftHiveMetastore_get_databases_args::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_databases_pargs::~ThriftHiveMetastore_get_databases_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_databases_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_databases_pargs");
 
   xfer += oprot->writeFieldBegin("pattern", ::apache::thrift::protocol::T_STRING, 1);
@@ -1069,9 +1202,15 @@ uint32_t ThriftHiveMetastore_get_databases_pargs::write(::apache::thrift::protoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_databases_result::~ThriftHiveMetastore_get_databases_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_databases_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1096,14 +1235,14 @@ uint32_t ThriftHiveMetastore_get_databases_result::read(::apache::thrift::protoc
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size425;
-            ::apache::thrift::protocol::TType _etype428;
-            xfer += iprot->readListBegin(_etype428, _size425);
-            this->success.resize(_size425);
-            uint32_t _i429;
-            for (_i429 = 0; _i429 < _size425; ++_i429)
+            uint32_t _size641;
+            ::apache::thrift::protocol::TType _etype644;
+            xfer += iprot->readListBegin(_etype644, _size641);
+            this->success.resize(_size641);
+            uint32_t _i645;
+            for (_i645 = 0; _i645 < _size641; ++_i645)
             {
-              xfer += iprot->readString(this->success[_i429]);
+              xfer += iprot->readString(this->success[_i645]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1142,10 +1281,10 @@ uint32_t ThriftHiveMetastore_get_databases_result::write(::apache::thrift::proto
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter430;
-      for (_iter430 = this->success.begin(); _iter430 != this->success.end(); ++_iter430)
+      std::vector<std::string> ::const_iterator _iter646;
+      for (_iter646 = this->success.begin(); _iter646 != this->success.end(); ++_iter646)
       {
-        xfer += oprot->writeString((*_iter430));
+        xfer += oprot->writeString((*_iter646));
       }
       xfer += oprot->writeListEnd();
     }
@@ -1160,6 +1299,11 @@ uint32_t ThriftHiveMetastore_get_databases_result::write(::apache::thrift::proto
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_databases_presult::~ThriftHiveMetastore_get_databases_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_databases_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1184,14 +1328,14 @@ uint32_t ThriftHiveMetastore_get_databases_presult::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size431;
-            ::apache::thrift::protocol::TType _etype434;
-            xfer += iprot->readListBegin(_etype434, _size431);
-            (*(this->success)).resize(_size431);
-            uint32_t _i435;
-            for (_i435 = 0; _i435 < _size431; ++_i435)
+            uint32_t _size647;
+            ::apache::thrift::protocol::TType _etype650;
+            xfer += iprot->readListBegin(_etype650, _size647);
+            (*(this->success)).resize(_size647);
+            uint32_t _i651;
+            for (_i651 = 0; _i651 < _size647; ++_i651)
             {
-              xfer += iprot->readString((*(this->success))[_i435]);
+              xfer += iprot->readString((*(this->success))[_i651]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1220,6 +1364,11 @@ uint32_t ThriftHiveMetastore_get_databases_presult::read(::apache::thrift::proto
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_databases_args::~ThriftHiveMetastore_get_all_databases_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_databases_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1249,22 +1398,36 @@ uint32_t ThriftHiveMetastore_get_all_databases_args::read(::apache::thrift::prot
 
 uint32_t ThriftHiveMetastore_get_all_databases_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_all_databases_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_databases_pargs::~ThriftHiveMetastore_get_all_databases_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_databases_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_all_databases_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_databases_result::~ThriftHiveMetastore_get_all_databases_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_databases_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1289,14 +1452,14 @@ uint32_t ThriftHiveMetastore_get_all_databases_result::read(::apache::thrift::pr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size436;
-            ::apache::thrift::protocol::TType _etype439;
-            xfer += iprot->readListBegin(_etype439, _size436);
-            this->success.resize(_size436);
-            uint32_t _i440;
-            for (_i440 = 0; _i440 < _size436; ++_i440)
+            uint32_t _size652;
+            ::apache::thrift::protocol::TType _etype655;
+            xfer += iprot->readListBegin(_etype655, _size652);
+            this->success.resize(_size652);
+            uint32_t _i656;
+            for (_i656 = 0; _i656 < _size652; ++_i656)
             {
-              xfer += iprot->readString(this->success[_i440]);
+              xfer += iprot->readString(this->success[_i656]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1335,10 +1498,10 @@ uint32_t ThriftHiveMetastore_get_all_databases_result::write(::apache::thrift::p
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter441;
-      for (_iter441 = this->success.begin(); _iter441 != this->success.end(); ++_iter441)
+      std::vector<std::string> ::const_iterator _iter657;
+      for (_iter657 = this->success.begin(); _iter657 != this->success.end(); ++_iter657)
       {
-        xfer += oprot->writeString((*_iter441));
+        xfer += oprot->writeString((*_iter657));
       }
       xfer += oprot->writeListEnd();
     }
@@ -1353,6 +1516,11 @@ uint32_t ThriftHiveMetastore_get_all_databases_result::write(::apache::thrift::p
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_databases_presult::~ThriftHiveMetastore_get_all_databases_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_databases_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1377,14 +1545,14 @@ uint32_t ThriftHiveMetastore_get_all_databases_presult::read(::apache::thrift::p
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size442;
-            ::apache::thrift::protocol::TType _etype445;
-            xfer += iprot->readListBegin(_etype445, _size442);
-            (*(this->success)).resize(_size442);
-            uint32_t _i446;
-            for (_i446 = 0; _i446 < _size442; ++_i446)
+            uint32_t _size658;
+            ::apache::thrift::protocol::TType _etype661;
+            xfer += iprot->readListBegin(_etype661, _size658);
+            (*(this->success)).resize(_size658);
+            uint32_t _i662;
+            for (_i662 = 0; _i662 < _size658; ++_i662)
             {
-              xfer += iprot->readString((*(this->success))[_i446]);
+              xfer += iprot->readString((*(this->success))[_i662]);
             }
             xfer += iprot->readListEnd();
           }
@@ -1413,6 +1581,11 @@ uint32_t ThriftHiveMetastore_get_all_databases_presult::read(::apache::thrift::p
   return xfer;
 }
 
+
+ThriftHiveMetastore_alter_database_args::~ThriftHiveMetastore_alter_database_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_alter_database_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1463,6 +1636,7 @@ uint32_t ThriftHiveMetastore_alter_database_args::read(::apache::thrift::protoco
 
 uint32_t ThriftHiveMetastore_alter_database_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_alter_database_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -1475,11 +1649,18 @@ uint32_t ThriftHiveMetastore_alter_database_args::write(::apache::thrift::protoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_alter_database_pargs::~ThriftHiveMetastore_alter_database_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_alter_database_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_alter_database_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -1492,9 +1673,15 @@ uint32_t ThriftHiveMetastore_alter_database_pargs::write(::apache::thrift::proto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_alter_database_result::~ThriftHiveMetastore_alter_database_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_alter_database_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1563,6 +1750,11 @@ uint32_t ThriftHiveMetastore_alter_database_result::write(::apache::thrift::prot
   return xfer;
 }
 
+
+ThriftHiveMetastore_alter_database_presult::~ThriftHiveMetastore_alter_database_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_alter_database_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1611,6 +1803,11 @@ uint32_t ThriftHiveMetastore_alter_database_presult::read(::apache::thrift::prot
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_args::~ThriftHiveMetastore_get_type_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1653,6 +1850,7 @@ uint32_t ThriftHiveMetastore_get_type_args::read(::apache::thrift::protocol::TPr
 
 uint32_t ThriftHiveMetastore_get_type_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_type_args");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -1661,11 +1859,18 @@ uint32_t ThriftHiveMetastore_get_type_args::write(::apache::thrift::protocol::TP
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_pargs::~ThriftHiveMetastore_get_type_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_type_pargs");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -1674,9 +1879,15 @@ uint32_t ThriftHiveMetastore_get_type_pargs::write(::apache::thrift::protocol::T
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_result::~ThriftHiveMetastore_get_type_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1757,6 +1968,11 @@ uint32_t ThriftHiveMetastore_get_type_result::write(::apache::thrift::protocol::
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_presult::~ThriftHiveMetastore_get_type_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1813,6 +2029,11 @@ uint32_t ThriftHiveMetastore_get_type_presult::read(::apache::thrift::protocol::
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_type_args::~ThriftHiveMetastore_create_type_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_type_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1855,6 +2076,7 @@ uint32_t ThriftHiveMetastore_create_type_args::read(::apache::thrift::protocol::
 
 uint32_t ThriftHiveMetastore_create_type_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_type_args");
 
   xfer += oprot->writeFieldBegin("type", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1863,11 +2085,18 @@ uint32_t ThriftHiveMetastore_create_type_args::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_type_pargs::~ThriftHiveMetastore_create_type_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_type_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_type_pargs");
 
   xfer += oprot->writeFieldBegin("type", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1876,9 +2105,15 @@ uint32_t ThriftHiveMetastore_create_type_pargs::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_type_result::~ThriftHiveMetastore_create_type_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_type_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1971,6 +2206,11 @@ uint32_t ThriftHiveMetastore_create_type_result::write(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_type_presult::~ThriftHiveMetastore_create_type_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_type_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2035,6 +2275,11 @@ uint32_t ThriftHiveMetastore_create_type_presult::read(::apache::thrift::protoco
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_type_args::~ThriftHiveMetastore_drop_type_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_type_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2077,6 +2322,7 @@ uint32_t ThriftHiveMetastore_drop_type_args::read(::apache::thrift::protocol::TP
 
 uint32_t ThriftHiveMetastore_drop_type_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_type_args");
 
   xfer += oprot->writeFieldBegin("type", ::apache::thrift::protocol::T_STRING, 1);
@@ -2085,11 +2331,18 @@ uint32_t ThriftHiveMetastore_drop_type_args::write(::apache::thrift::protocol::T
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_type_pargs::~ThriftHiveMetastore_drop_type_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_type_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_type_pargs");
 
   xfer += oprot->writeFieldBegin("type", ::apache::thrift::protocol::T_STRING, 1);
@@ -2098,9 +2351,15 @@ uint32_t ThriftHiveMetastore_drop_type_pargs::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_type_result::~ThriftHiveMetastore_drop_type_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_type_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2181,6 +2440,11 @@ uint32_t ThriftHiveMetastore_drop_type_result::write(::apache::thrift::protocol:
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_type_presult::~ThriftHiveMetastore_drop_type_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_type_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2237,6 +2501,11 @@ uint32_t ThriftHiveMetastore_drop_type_presult::read(::apache::thrift::protocol:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_all_args::~ThriftHiveMetastore_get_type_all_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_all_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2279,6 +2548,7 @@ uint32_t ThriftHiveMetastore_get_type_all_args::read(::apache::thrift::protocol:
 
 uint32_t ThriftHiveMetastore_get_type_all_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_type_all_args");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2287,11 +2557,18 @@ uint32_t ThriftHiveMetastore_get_type_all_args::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_all_pargs::~ThriftHiveMetastore_get_type_all_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_all_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_type_all_pargs");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2300,9 +2577,15 @@ uint32_t ThriftHiveMetastore_get_type_all_pargs::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_all_result::~ThriftHiveMetastore_get_type_all_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_all_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2327,17 +2610,17 @@ uint32_t ThriftHiveMetastore_get_type_all_result::read(::apache::thrift::protoco
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->success.clear();
-            uint32_t _size447;
-            ::apache::thrift::protocol::TType _ktype448;
-            ::apache::thrift::protocol::TType _vtype449;
-            xfer += iprot->readMapBegin(_ktype448, _vtype449, _size447);
-            uint32_t _i451;
-            for (_i451 = 0; _i451 < _size447; ++_i451)
+            uint32_t _size663;
+            ::apache::thrift::protocol::TType _ktype664;
+            ::apache::thrift::protocol::TType _vtype665;
+            xfer += iprot->readMapBegin(_ktype664, _vtype665, _size663);
+            uint32_t _i667;
+            for (_i667 = 0; _i667 < _size663; ++_i667)
             {
-              std::string _key452;
-              xfer += iprot->readString(_key452);
-              Type& _val453 = this->success[_key452];
-              xfer += _val453.read(iprot);
+              std::string _key668;
+              xfer += iprot->readString(_key668);
+              Type& _val669 = this->success[_key668];
+              xfer += _val669.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2376,11 +2659,11 @@ uint32_t ThriftHiveMetastore_get_type_all_result::write(::apache::thrift::protoc
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_MAP, 0);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::map<std::string, Type> ::const_iterator _iter454;
-      for (_iter454 = this->success.begin(); _iter454 != this->success.end(); ++_iter454)
+      std::map<std::string, Type> ::const_iterator _iter670;
+      for (_iter670 = this->success.begin(); _iter670 != this->success.end(); ++_iter670)
       {
-        xfer += oprot->writeString(_iter454->first);
-        xfer += _iter454->second.write(oprot);
+        xfer += oprot->writeString(_iter670->first);
+        xfer += _iter670->second.write(oprot);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -2395,6 +2678,11 @@ uint32_t ThriftHiveMetastore_get_type_all_result::write(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_type_all_presult::~ThriftHiveMetastore_get_type_all_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_type_all_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2419,17 +2707,17 @@ uint32_t ThriftHiveMetastore_get_type_all_presult::read(::apache::thrift::protoc
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             (*(this->success)).clear();
-            uint32_t _size455;
-            ::apache::thrift::protocol::TType _ktype456;
-            ::apache::thrift::protocol::TType _vtype457;
-            xfer += iprot->readMapBegin(_ktype456, _vtype457, _size455);
-            uint32_t _i459;
-            for (_i459 = 0; _i459 < _size455; ++_i459)
+            uint32_t _size671;
+            ::apache::thrift::protocol::TType _ktype672;
+            ::apache::thrift::protocol::TType _vtype673;
+            xfer += iprot->readMapBegin(_ktype672, _vtype673, _size671);
+            uint32_t _i675;
+            for (_i675 = 0; _i675 < _size671; ++_i675)
             {
-              std::string _key460;
-              xfer += iprot->readString(_key460);
-              Type& _val461 = (*(this->success))[_key460];
-              xfer += _val461.read(iprot);
+              std::string _key676;
+              xfer += iprot->readString(_key676);
+              Type& _val677 = (*(this->success))[_key676];
+              xfer += _val677.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2458,6 +2746,11 @@ uint32_t ThriftHiveMetastore_get_type_all_presult::read(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_args::~ThriftHiveMetastore_get_fields_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2508,6 +2801,7 @@ uint32_t ThriftHiveMetastore_get_fields_args::read(::apache::thrift::protocol::T
 
 uint32_t ThriftHiveMetastore_get_fields_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_fields_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2520,11 +2814,18 @@ uint32_t ThriftHiveMetastore_get_fields_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_pargs::~ThriftHiveMetastore_get_fields_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_fields_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2537,9 +2838,15 @@ uint32_t ThriftHiveMetastore_get_fields_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_result::~ThriftHiveMetastore_get_fields_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2564,14 +2871,14 @@ uint32_t ThriftHiveMetastore_get_fields_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size462;
-            ::apache::thrift::protocol::TType _etype465;
-            xfer += iprot->readListBegin(_etype465, _size462);
-            this->success.resize(_size462);
-            uint32_t _i466;
-            for (_i466 = 0; _i466 < _size462; ++_i466)
+            uint32_t _size678;
+            ::apache::thrift::protocol::TType _etype681;
+            xfer += iprot->readListBegin(_etype681, _size678);
+            this->success.resize(_size678);
+            uint32_t _i682;
+            for (_i682 = 0; _i682 < _size678; ++_i682)
             {
-              xfer += this->success[_i466].read(iprot);
+              xfer += this->success[_i682].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -2626,10 +2933,10 @@ uint32_t ThriftHiveMetastore_get_fields_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter467;
-      for (_iter467 = this->success.begin(); _iter467 != this->success.end(); ++_iter467)
+      std::vector<FieldSchema> ::const_iterator _iter683;
+      for (_iter683 = this->success.begin(); _iter683 != this->success.end(); ++_iter683)
       {
-        xfer += (*_iter467).write(oprot);
+        xfer += (*_iter683).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -2652,6 +2959,11 @@ uint32_t ThriftHiveMetastore_get_fields_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_presult::~ThriftHiveMetastore_get_fields_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2676,14 +2988,14 @@ uint32_t ThriftHiveMetastore_get_fields_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size468;
-            ::apache::thrift::protocol::TType _etype471;
-            xfer += iprot->readListBegin(_etype471, _size468);
-            (*(this->success)).resize(_size468);
-            uint32_t _i472;
-            for (_i472 = 0; _i472 < _size468; ++_i472)
+            uint32_t _size684;
+            ::apache::thrift::protocol::TType _etype687;
+            xfer += iprot->readListBegin(_etype687, _size684);
+            (*(this->success)).resize(_size684);
+            uint32_t _i688;
+            for (_i688 = 0; _i688 < _size684; ++_i688)
             {
-              xfer += (*(this->success))[_i472].read(iprot);
+              xfer += (*(this->success))[_i688].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -2728,6 +3040,11 @@ uint32_t ThriftHiveMetastore_get_fields_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_with_environment_context_args::~ThriftHiveMetastore_get_fields_with_environment_context_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_with_environment_context_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2786,6 +3103,7 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_args::read(::ap
 
 uint32_t ThriftHiveMetastore_get_fields_with_environment_context_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_fields_with_environment_context_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2802,11 +3120,18 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_args::write(::a
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_with_environment_context_pargs::~ThriftHiveMetastore_get_fields_with_environment_context_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_with_environment_context_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_fields_with_environment_context_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2823,9 +3148,15 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_pargs::write(::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_with_environment_context_result::~ThriftHiveMetastore_get_fields_with_environment_context_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2850,14 +3181,14 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::read(::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size473;
-            ::apache::thrift::protocol::TType _etype476;
-            xfer += iprot->readListBegin(_etype476, _size473);
-            this->success.resize(_size473);
-            uint32_t _i477;
-            for (_i477 = 0; _i477 < _size473; ++_i477)
+            uint32_t _size689;
+            ::apache::thrift::protocol::TType _etype692;
+            xfer += iprot->readListBegin(_etype692, _size689);
+            this->success.resize(_size689);
+            uint32_t _i693;
+            for (_i693 = 0; _i693 < _size689; ++_i693)
             {
-              xfer += this->success[_i477].read(iprot);
+              xfer += this->success[_i693].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -2912,10 +3243,10 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::write(:
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter478;
-      for (_iter478 = this->success.begin(); _iter478 != this->success.end(); ++_iter478)
+      std::vector<FieldSchema> ::const_iterator _iter694;
+      for (_iter694 = this->success.begin(); _iter694 != this->success.end(); ++_iter694)
       {
-        xfer += (*_iter478).write(oprot);
+        xfer += (*_iter694).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -2938,6 +3269,11 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_result::write(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_fields_with_environment_context_presult::~ThriftHiveMetastore_get_fields_with_environment_context_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_fields_with_environment_context_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -2962,14 +3298,14 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_presult::read(:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size479;
-            ::apache::thrift::protocol::TType _etype482;
-            xfer += iprot->readListBegin(_etype482, _size479);
-            (*(this->success)).resize(_size479);
-            uint32_t _i483;
-            for (_i483 = 0; _i483 < _size479; ++_i483)
+            uint32_t _size695;
+            ::apache::thrift::protocol::TType _etype698;
+            xfer += iprot->readListBegin(_etype698, _size695);
+            (*(this->success)).resize(_size695);
+            uint32_t _i699;
+            for (_i699 = 0; _i699 < _size695; ++_i699)
             {
-              xfer += (*(this->success))[_i483].read(iprot);
+              xfer += (*(this->success))[_i699].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3014,6 +3350,11 @@ uint32_t ThriftHiveMetastore_get_fields_with_environment_context_presult::read(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_args::~ThriftHiveMetastore_get_schema_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3064,6 +3405,7 @@ uint32_t ThriftHiveMetastore_get_schema_args::read(::apache::thrift::protocol::T
 
 uint32_t ThriftHiveMetastore_get_schema_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_schema_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -3076,11 +3418,18 @@ uint32_t ThriftHiveMetastore_get_schema_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_pargs::~ThriftHiveMetastore_get_schema_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_schema_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -3093,9 +3442,15 @@ uint32_t ThriftHiveMetastore_get_schema_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_result::~ThriftHiveMetastore_get_schema_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3120,14 +3475,14 @@ uint32_t ThriftHiveMetastore_get_schema_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size484;
-            ::apache::thrift::protocol::TType _etype487;
-            xfer += iprot->readListBegin(_etype487, _size484);
-            this->success.resize(_size484);
-            uint32_t _i488;
-            for (_i488 = 0; _i488 < _size484; ++_i488)
+            uint32_t _size700;
+            ::apache::thrift::protocol::TType _etype703;
+            xfer += iprot->readListBegin(_etype703, _size700);
+            this->success.resize(_size700);
+            uint32_t _i704;
+            for (_i704 = 0; _i704 < _size700; ++_i704)
             {
-              xfer += this->success[_i488].read(iprot);
+              xfer += this->success[_i704].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3182,10 +3537,10 @@ uint32_t ThriftHiveMetastore_get_schema_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter489;
-      for (_iter489 = this->success.begin(); _iter489 != this->success.end(); ++_iter489)
+      std::vector<FieldSchema> ::const_iterator _iter705;
+      for (_iter705 = this->success.begin(); _iter705 != this->success.end(); ++_iter705)
       {
-        xfer += (*_iter489).write(oprot);
+        xfer += (*_iter705).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3208,6 +3563,11 @@ uint32_t ThriftHiveMetastore_get_schema_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_presult::~ThriftHiveMetastore_get_schema_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3232,14 +3592,14 @@ uint32_t ThriftHiveMetastore_get_schema_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size490;
-            ::apache::thrift::protocol::TType _etype493;
-            xfer += iprot->readListBegin(_etype493, _size490);
-            (*(this->success)).resize(_size490);
-            uint32_t _i494;
-            for (_i494 = 0; _i494 < _size490; ++_i494)
+            uint32_t _size706;
+            ::apache::thrift::protocol::TType _etype709;
+            xfer += iprot->readListBegin(_etype709, _size706);
+            (*(this->success)).resize(_size706);
+            uint32_t _i710;
+            for (_i710 = 0; _i710 < _size706; ++_i710)
             {
-              xfer += (*(this->success))[_i494].read(iprot);
+              xfer += (*(this->success))[_i710].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3284,6 +3644,11 @@ uint32_t ThriftHiveMetastore_get_schema_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_with_environment_context_args::~ThriftHiveMetastore_get_schema_with_environment_context_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_with_environment_context_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3342,6 +3707,7 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_args::read(::ap
 
 uint32_t ThriftHiveMetastore_get_schema_with_environment_context_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_schema_with_environment_context_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -3358,11 +3724,18 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_args::write(::a
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
-uint32_t ThriftHiveMetastore_get_schema_with_environment_context_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
-  uint32_t xfer = 0;
+
+ThriftHiveMetastore_get_schema_with_environment_context_pargs::~ThriftHiveMetastore_get_schema_with_environment_context_pargs() throw() {
+}
+
+
+uint32_t ThriftHiveMetastore_get_schema_with_environment_context_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
+  uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_schema_with_environment_context_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -3379,9 +3752,15 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_pargs::write(::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_with_environment_context_result::~ThriftHiveMetastore_get_schema_with_environment_context_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3406,14 +3785,14 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::read(::
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size495;
-            ::apache::thrift::protocol::TType _etype498;
-            xfer += iprot->readListBegin(_etype498, _size495);
-            this->success.resize(_size495);
-            uint32_t _i499;
-            for (_i499 = 0; _i499 < _size495; ++_i499)
+            uint32_t _size711;
+            ::apache::thrift::protocol::TType _etype714;
+            xfer += iprot->readListBegin(_etype714, _size711);
+            this->success.resize(_size711);
+            uint32_t _i715;
+            for (_i715 = 0; _i715 < _size711; ++_i715)
             {
-              xfer += this->success[_i499].read(iprot);
+              xfer += this->success[_i715].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3468,10 +3847,10 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::write(:
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<FieldSchema> ::const_iterator _iter500;
-      for (_iter500 = this->success.begin(); _iter500 != this->success.end(); ++_iter500)
+      std::vector<FieldSchema> ::const_iterator _iter716;
+      for (_iter716 = this->success.begin(); _iter716 != this->success.end(); ++_iter716)
       {
-        xfer += (*_iter500).write(oprot);
+        xfer += (*_iter716).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3494,6 +3873,11 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_result::write(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_schema_with_environment_context_presult::~ThriftHiveMetastore_get_schema_with_environment_context_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_schema_with_environment_context_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3518,14 +3902,14 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_presult::read(:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size501;
-            ::apache::thrift::protocol::TType _etype504;
-            xfer += iprot->readListBegin(_etype504, _size501);
-            (*(this->success)).resize(_size501);
-            uint32_t _i505;
-            for (_i505 = 0; _i505 < _size501; ++_i505)
+            uint32_t _size717;
+            ::apache::thrift::protocol::TType _etype720;
+            xfer += iprot->readListBegin(_etype720, _size717);
+            (*(this->success)).resize(_size717);
+            uint32_t _i721;
+            for (_i721 = 0; _i721 < _size717; ++_i721)
             {
-              xfer += (*(this->success))[_i505].read(iprot);
+              xfer += (*(this->success))[_i721].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3570,6 +3954,11 @@ uint32_t ThriftHiveMetastore_get_schema_with_environment_context_presult::read(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_args::~ThriftHiveMetastore_create_table_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3612,6 +4001,7 @@ uint32_t ThriftHiveMetastore_create_table_args::read(::apache::thrift::protocol:
 
 uint32_t ThriftHiveMetastore_create_table_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_table_args");
 
   xfer += oprot->writeFieldBegin("tbl", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -3620,11 +4010,18 @@ uint32_t ThriftHiveMetastore_create_table_args::write(::apache::thrift::protocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_pargs::~ThriftHiveMetastore_create_table_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_table_pargs");
 
   xfer += oprot->writeFieldBegin("tbl", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -3633,9 +4030,15 @@ uint32_t ThriftHiveMetastore_create_table_pargs::write(::apache::thrift::protoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_result::~ThriftHiveMetastore_create_table_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3728,6 +4131,11 @@ uint32_t ThriftHiveMetastore_create_table_result::write(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_presult::~ThriftHiveMetastore_create_table_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3792,6 +4200,11 @@ uint32_t ThriftHiveMetastore_create_table_presult::read(::apache::thrift::protoc
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_with_environment_context_args::~ThriftHiveMetastore_create_table_with_environment_context_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_with_environment_context_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3842,6 +4255,7 @@ uint32_t ThriftHiveMetastore_create_table_with_environment_context_args::read(::
 
 uint32_t ThriftHiveMetastore_create_table_with_environment_context_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_table_with_environment_context_args");
 
   xfer += oprot->writeFieldBegin("tbl", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -3854,11 +4268,18 @@ uint32_t ThriftHiveMetastore_create_table_with_environment_context_args::write(:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_with_environment_context_pargs::~ThriftHiveMetastore_create_table_with_environment_context_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_with_environment_context_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_create_table_with_environment_context_pargs");
 
   xfer += oprot->writeFieldBegin("tbl", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -3871,9 +4292,15 @@ uint32_t ThriftHiveMetastore_create_table_with_environment_context_pargs::write(
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_with_environment_context_result::~ThriftHiveMetastore_create_table_with_environment_context_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_with_environment_context_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -3966,6 +4393,11 @@ uint32_t ThriftHiveMetastore_create_table_with_environment_context_result::write
   return xfer;
 }
 
+
+ThriftHiveMetastore_create_table_with_environment_context_presult::~ThriftHiveMetastore_create_table_with_environment_context_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_create_table_with_environment_context_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4030,6 +4462,11 @@ uint32_t ThriftHiveMetastore_create_table_with_environment_context_presult::read
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_args::~ThriftHiveMetastore_drop_table_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4088,6 +4525,7 @@ uint32_t ThriftHiveMetastore_drop_table_args::read(::apache::thrift::protocol::T
 
 uint32_t ThriftHiveMetastore_drop_table_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_table_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4104,11 +4542,18 @@ uint32_t ThriftHiveMetastore_drop_table_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_pargs::~ThriftHiveMetastore_drop_table_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_table_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4125,9 +4570,15 @@ uint32_t ThriftHiveMetastore_drop_table_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_result::~ThriftHiveMetastore_drop_table_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4196,6 +4647,11 @@ uint32_t ThriftHiveMetastore_drop_table_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_presult::~ThriftHiveMetastore_drop_table_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4244,6 +4700,11 @@ uint32_t ThriftHiveMetastore_drop_table_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_with_environment_context_args::~ThriftHiveMetastore_drop_table_with_environment_context_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_with_environment_context_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4310,6 +4771,7 @@ uint32_t ThriftHiveMetastore_drop_table_with_environment_context_args::read(::ap
 
 uint32_t ThriftHiveMetastore_drop_table_with_environment_context_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_table_with_environment_context_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4330,11 +4792,18 @@ uint32_t ThriftHiveMetastore_drop_table_with_environment_context_args::write(::a
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_with_environment_context_pargs::~ThriftHiveMetastore_drop_table_with_environment_context_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_with_environment_context_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_drop_table_with_environment_context_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4355,9 +4824,15 @@ uint32_t ThriftHiveMetastore_drop_table_with_environment_context_pargs::write(::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_with_environment_context_result::~ThriftHiveMetastore_drop_table_with_environment_context_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_with_environment_context_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4426,6 +4901,11 @@ uint32_t ThriftHiveMetastore_drop_table_with_environment_context_result::write(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_drop_table_with_environment_context_presult::~ThriftHiveMetastore_drop_table_with_environment_context_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_drop_table_with_environment_context_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4474,6 +4954,11 @@ uint32_t ThriftHiveMetastore_drop_table_with_environment_context_presult::read(:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_tables_args::~ThriftHiveMetastore_get_tables_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_tables_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4524,6 +5009,7 @@ uint32_t ThriftHiveMetastore_get_tables_args::read(::apache::thrift::protocol::T
 
 uint32_t ThriftHiveMetastore_get_tables_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_tables_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -4536,11 +5022,18 @@ uint32_t ThriftHiveMetastore_get_tables_args::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_tables_pargs::~ThriftHiveMetastore_get_tables_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_tables_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_tables_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -4553,9 +5046,15 @@ uint32_t ThriftHiveMetastore_get_tables_pargs::write(::apache::thrift::protocol:
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_tables_result::~ThriftHiveMetastore_get_tables_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_tables_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4580,14 +5079,14 @@ uint32_t ThriftHiveMetastore_get_tables_result::read(::apache::thrift::protocol:
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size506;
-            ::apache::thrift::protocol::TType _etype509;
-            xfer += iprot->readListBegin(_etype509, _size506);
-            this->success.resize(_size506);
-            uint32_t _i510;
-            for (_i510 = 0; _i510 < _size506; ++_i510)
+            uint32_t _size722;
+            ::apache::thrift::protocol::TType _etype725;
+            xfer += iprot->readListBegin(_etype725, _size722);
+            this->success.resize(_size722);
+            uint32_t _i726;
+            for (_i726 = 0; _i726 < _size722; ++_i726)
             {
-              xfer += iprot->readString(this->success[_i510]);
+              xfer += iprot->readString(this->success[_i726]);
             }
             xfer += iprot->readListEnd();
           }
@@ -4626,10 +5125,10 @@ uint32_t ThriftHiveMetastore_get_tables_result::write(::apache::thrift::protocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter511;
-      for (_iter511 = this->success.begin(); _iter511 != this->success.end(); ++_iter511)
+      std::vector<std::string> ::const_iterator _iter727;
+      for (_iter727 = this->success.begin(); _iter727 != this->success.end(); ++_iter727)
       {
-        xfer += oprot->writeString((*_iter511));
+        xfer += oprot->writeString((*_iter727));
       }
       xfer += oprot->writeListEnd();
     }
@@ -4644,6 +5143,11 @@ uint32_t ThriftHiveMetastore_get_tables_result::write(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_tables_presult::~ThriftHiveMetastore_get_tables_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_tables_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4668,14 +5172,14 @@ uint32_t ThriftHiveMetastore_get_tables_presult::read(::apache::thrift::protocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size512;
-            ::apache::thrift::protocol::TType _etype515;
-            xfer += iprot->readListBegin(_etype515, _size512);
-            (*(this->success)).resize(_size512);
-            uint32_t _i516;
-            for (_i516 = 0; _i516 < _size512; ++_i516)
+            uint32_t _size728;
+            ::apache::thrift::protocol::TType _etype731;
+            xfer += iprot->readListBegin(_etype731, _size728);
+            (*(this->success)).resize(_size728);
+            uint32_t _i732;
+            for (_i732 = 0; _i732 < _size728; ++_i732)
             {
-              xfer += iprot->readString((*(this->success))[_i516]);
+              xfer += iprot->readString((*(this->success))[_i732]);
             }
             xfer += iprot->readListEnd();
           }
@@ -4704,6 +5208,11 @@ uint32_t ThriftHiveMetastore_get_tables_presult::read(::apache::thrift::protocol
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_tables_args::~ThriftHiveMetastore_get_all_tables_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_tables_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4746,6 +5255,7 @@ uint32_t ThriftHiveMetastore_get_all_tables_args::read(::apache::thrift::protoco
 
 uint32_t ThriftHiveMetastore_get_all_tables_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_all_tables_args");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -4754,11 +5264,18 @@ uint32_t ThriftHiveMetastore_get_all_tables_args::write(::apache::thrift::protoc
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_tables_pargs::~ThriftHiveMetastore_get_all_tables_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_tables_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_all_tables_pargs");
 
   xfer += oprot->writeFieldBegin("db_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -4767,9 +5284,15 @@ uint32_t ThriftHiveMetastore_get_all_tables_pargs::write(::apache::thrift::proto
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_tables_result::~ThriftHiveMetastore_get_all_tables_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_tables_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4794,14 +5317,14 @@ uint32_t ThriftHiveMetastore_get_all_tables_result::read(::apache::thrift::proto
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size517;
-            ::apache::thrift::protocol::TType _etype520;
-            xfer += iprot->readListBegin(_etype520, _size517);
-            this->success.resize(_size517);
-            uint32_t _i521;
-            for (_i521 = 0; _i521 < _size517; ++_i521)
+            uint32_t _size733;
+            ::apache::thrift::protocol::TType _etype736;
+            xfer += iprot->readListBegin(_etype736, _size733);
+            this->success.resize(_size733);
+            uint32_t _i737;
+            for (_i737 = 0; _i737 < _size733; ++_i737)
             {
-              xfer += iprot->readString(this->success[_i521]);
+              xfer += iprot->readString(this->success[_i737]);
             }
             xfer += iprot->readListEnd();
           }
@@ -4840,10 +5363,10 @@ uint32_t ThriftHiveMetastore_get_all_tables_result::write(::apache::thrift::prot
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter522;
-      for (_iter522 = this->success.begin(); _iter522 != this->success.end(); ++_iter522)
+      std::vector<std::string> ::const_iterator _iter738;
+      for (_iter738 = this->success.begin(); _iter738 != this->success.end(); ++_iter738)
       {
-        xfer += oprot->writeString((*_iter522));
+        xfer += oprot->writeString((*_iter738));
       }
       xfer += oprot->writeListEnd();
     }
@@ -4858,6 +5381,11 @@ uint32_t ThriftHiveMetastore_get_all_tables_result::write(::apache::thrift::prot
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_all_tables_presult::~ThriftHiveMetastore_get_all_tables_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_all_tables_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4882,14 +5410,14 @@ uint32_t ThriftHiveMetastore_get_all_tables_presult::read(::apache::thrift::prot
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size523;
-            ::apache::thrift::protocol::TType _etype526;
-            xfer += iprot->readListBegin(_etype526, _size523);
-            (*(this->success)).resize(_size523);
-            uint32_t _i527;
-            for (_i527 = 0; _i527 < _size523; ++_i527)
+            uint32_t _size739;
+            ::apache::thrift::protocol::TType _etype742;
+            xfer += iprot->readListBegin(_etype742, _size739);
+            (*(this->success)).resize(_size739);
+            uint32_t _i743;
+            for (_i743 = 0; _i743 < _size739; ++_i743)
             {
-              xfer += iprot->readString((*(this->success))[_i527]);
+              xfer += iprot->readString((*(this->success))[_i743]);
             }
             xfer += iprot->readListEnd();
           }
@@ -4918,6 +5446,11 @@ uint32_t ThriftHiveMetastore_get_all_tables_presult::read(::apache::thrift::prot
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_args::~ThriftHiveMetastore_get_table_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -4968,6 +5501,7 @@ uint32_t ThriftHiveMetastore_get_table_args::read(::apache::thrift::protocol::TP
 
 uint32_t ThriftHiveMetastore_get_table_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4980,11 +5514,18 @@ uint32_t ThriftHiveMetastore_get_table_args::write(::apache::thrift::protocol::T
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_pargs::~ThriftHiveMetastore_get_table_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -4997,9 +5538,15 @@ uint32_t ThriftHiveMetastore_get_table_pargs::write(::apache::thrift::protocol::
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_result::~ThriftHiveMetastore_get_table_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5080,6 +5627,11 @@ uint32_t ThriftHiveMetastore_get_table_result::write(::apache::thrift::protocol:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_presult::~ThriftHiveMetastore_get_table_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5136,6 +5688,11 @@ uint32_t ThriftHiveMetastore_get_table_presult::read(::apache::thrift::protocol:
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_objects_by_name_args::~ThriftHiveMetastore_get_table_objects_by_name_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5168,14 +5725,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::read(::apache::thri
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->tbl_names.clear();
-            uint32_t _size528;
-            ::apache::thrift::protocol::TType _etype531;
-            xfer += iprot->readListBegin(_etype531, _size528);
-            this->tbl_names.resize(_size528);
-            uint32_t _i532;
-            for (_i532 = 0; _i532 < _size528; ++_i532)
+            uint32_t _size744;
+            ::apache::thrift::protocol::TType _etype747;
+            xfer += iprot->readListBegin(_etype747, _size744);
+            this->tbl_names.resize(_size744);
+            uint32_t _i748;
+            for (_i748 = 0; _i748 < _size744; ++_i748)
             {
-              xfer += iprot->readString(this->tbl_names[_i532]);
+              xfer += iprot->readString(this->tbl_names[_i748]);
             }
             xfer += iprot->readListEnd();
           }
@@ -5198,6 +5755,7 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::read(::apache::thri
 
 uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_objects_by_name_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -5207,10 +5765,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::write(::apache::thr
   xfer += oprot->writeFieldBegin("tbl_names", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->tbl_names.size()));
-    std::vector<std::string> ::const_iterator _iter533;
-    for (_iter533 = this->tbl_names.begin(); _iter533 != this->tbl_names.end(); ++_iter533)
+    std::vector<std::string> ::const_iterator _iter749;
+    for (_iter749 = this->tbl_names.begin(); _iter749 != this->tbl_names.end(); ++_iter749)
     {
-      xfer += oprot->writeString((*_iter533));
+      xfer += oprot->writeString((*_iter749));
     }
     xfer += oprot->writeListEnd();
   }
@@ -5218,11 +5776,18 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_args::write(::apache::thr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_objects_by_name_pargs::~ThriftHiveMetastore_get_table_objects_by_name_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_objects_by_name_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_objects_by_name_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -5232,10 +5797,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_pargs::write(::apache::th
   xfer += oprot->writeFieldBegin("tbl_names", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*(this->tbl_names)).size()));
-    std::vector<std::string> ::const_iterator _iter534;
-    for (_iter534 = (*(this->tbl_names)).begin(); _iter534 != (*(this->tbl_names)).end(); ++_iter534)
+    std::vector<std::string> ::const_iterator _iter750;
+    for (_iter750 = (*(this->tbl_names)).begin(); _iter750 != (*(this->tbl_names)).end(); ++_iter750)
     {
-      xfer += oprot->writeString((*_iter534));
+      xfer += oprot->writeString((*_iter750));
     }
     xfer += oprot->writeListEnd();
   }
@@ -5243,9 +5808,15 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_pargs::write(::apache::th
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_objects_by_name_result::~ThriftHiveMetastore_get_table_objects_by_name_result() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5270,14 +5841,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::read(::apache::th
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size535;
-            ::apache::thrift::protocol::TType _etype538;
-            xfer += iprot->readListBegin(_etype538, _size535);
-            this->success.resize(_size535);
-            uint32_t _i539;
-            for (_i539 = 0; _i539 < _size535; ++_i539)
+            uint32_t _size751;
+            ::apache::thrift::protocol::TType _etype754;
+            xfer += iprot->readListBegin(_etype754, _size751);
+            this->success.resize(_size751);
+            uint32_t _i755;
+            for (_i755 = 0; _i755 < _size751; ++_i755)
             {
-              xfer += this->success[_i539].read(iprot);
+              xfer += this->success[_i755].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -5332,10 +5903,10 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::write(::apache::t
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->success.size()));
-      std::vector<Table> ::const_iterator _iter540;
-      for (_iter540 = this->success.begin(); _iter540 != this->success.end(); ++_iter540)
+      std::vector<Table> ::const_iterator _iter756;
+      for (_iter756 = this->success.begin(); _iter756 != this->success.end(); ++_iter756)
       {
-        xfer += (*_iter540).write(oprot);
+        xfer += (*_iter756).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -5358,6 +5929,11 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_result::write(::apache::t
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_objects_by_name_presult::~ThriftHiveMetastore_get_table_objects_by_name_presult() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_objects_by_name_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5382,14 +5958,14 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_presult::read(::apache::t
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size541;
-            ::apache::thrift::protocol::TType _etype544;
-            xfer += iprot->readListBegin(_etype544, _size541);
-            (*(this->success)).resize(_size541);
-            uint32_t _i545;
-            for (_i545 = 0; _i545 < _size541; ++_i545)
+            uint32_t _size757;
+            ::apache::thrift::protocol::TType _etype760;
+            xfer += iprot->readListBegin(_etype760, _size757);
+            (*(this->success)).resize(_size757);
+            uint32_t _i761;
+            for (_i761 = 0; _i761 < _size757; ++_i761)
             {
-              xfer += (*(this->success))[_i545].read(iprot);
+              xfer += (*(this->success))[_i761].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -5434,6 +6010,11 @@ uint32_t ThriftHiveMetastore_get_table_objects_by_name_presult::read(::apache::t
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_names_by_filter_args::~ThriftHiveMetastore_get_table_names_by_filter_args() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_names_by_filter_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -5492,6 +6073,7 @@ uint32_t ThriftHiveMetastore_get_table_names_by_filter_args::read(::apache::thri
 
 uint32_t ThriftHiveMetastore_get_table_names_by_filter_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_names_by_filter_args");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -5508,11 +6090,18 @@ uint32_t ThriftHiveMetastore_get_table_names_by_filter_args::write(::apache::thr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHiveMetastore_get_table_names_by_filter_pargs::~ThriftHiveMetastore_get_table_names_by_filter_pargs() throw() {
+}
+
+
 uint32_t ThriftHiveMetastore_get_table_names_by_filter_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHiveMetastore_get_table_names_by_filter_pargs");
 
   xfer += oprot->writeFieldBegin("dbname", ::apache::thrift::protocol::T_STRING, 1);
@@ -5529,9 +6118,15 @@ uint32_t ThriftHiveMetastore_ge

<TRUNCATED>

[18/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/megastruct_types.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/megastruct_types.cpp b/serde/src/gen/thrift/gen-cpp/megastruct_types.cpp
index 2d46b7f..6123f7d 100644
--- a/serde/src/gen/thrift/gen-cpp/megastruct_types.cpp
+++ b/serde/src/gen/thrift/gen-cpp/megastruct_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "megastruct_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 
 
@@ -20,6 +23,21 @@ const char* _kMyEnumNames[] = {
 };
 const std::map<int, const char*> _MyEnum_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(2, _kMyEnumValues, _kMyEnumNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
+
+MiniStruct::~MiniStruct() throw() {
+}
+
+
+void MiniStruct::__set_my_string(const std::string& val) {
+  this->my_string = val;
+__isset.my_string = true;
+}
+
+void MiniStruct::__set_my_enum(const MyEnum::type val) {
+  this->my_enum = val;
+__isset.my_enum = true;
+}
+
 const char* MiniStruct::ascii_fingerprint = "4ED2B10931906B61ED0B1592EE860A37";
 const uint8_t MiniStruct::binary_fingerprint[16] = {0x4E,0xD2,0xB1,0x09,0x31,0x90,0x6B,0x61,0xED,0x0B,0x15,0x92,0xEE,0x86,0x0A,0x37};
 
@@ -75,6 +93,7 @@ uint32_t MiniStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t MiniStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("MiniStruct");
 
   if (this->__isset.my_string) {
@@ -89,6 +108,7 @@ uint32_t MiniStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -99,6 +119,131 @@ void swap(MiniStruct &a, MiniStruct &b) {
   swap(a.__isset, b.__isset);
 }
 
+MiniStruct::MiniStruct(const MiniStruct& other1) {
+  my_string = other1.my_string;
+  my_enum = other1.my_enum;
+  __isset = other1.__isset;
+}
+MiniStruct& MiniStruct::operator=(const MiniStruct& other2) {
+  my_string = other2.my_string;
+  my_enum = other2.my_enum;
+  __isset = other2.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const MiniStruct& obj) {
+  using apache::thrift::to_string;
+  out << "MiniStruct(";
+  out << "my_string="; (obj.__isset.my_string ? (out << to_string(obj.my_string)) : (out << "<null>"));
+  out << ", " << "my_enum="; (obj.__isset.my_enum ? (out << to_string(obj.my_enum)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+MegaStruct::~MegaStruct() throw() {
+}
+
+
+void MegaStruct::__set_my_bool(const bool val) {
+  this->my_bool = val;
+__isset.my_bool = true;
+}
+
+void MegaStruct::__set_my_byte(const int8_t val) {
+  this->my_byte = val;
+__isset.my_byte = true;
+}
+
+void MegaStruct::__set_my_16bit_int(const int16_t val) {
+  this->my_16bit_int = val;
+__isset.my_16bit_int = true;
+}
+
+void MegaStruct::__set_my_32bit_int(const int32_t val) {
+  this->my_32bit_int = val;
+__isset.my_32bit_int = true;
+}
+
+void MegaStruct::__set_my_64bit_int(const int64_t val) {
+  this->my_64bit_int = val;
+__isset.my_64bit_int = true;
+}
+
+void MegaStruct::__set_my_double(const double val) {
+  this->my_double = val;
+__isset.my_double = true;
+}
+
+void MegaStruct::__set_my_string(const std::string& val) {
+  this->my_string = val;
+__isset.my_string = true;
+}
+
+void MegaStruct::__set_my_binary(const std::string& val) {
+  this->my_binary = val;
+__isset.my_binary = true;
+}
+
+void MegaStruct::__set_my_string_string_map(const std::map<std::string, std::string> & val) {
+  this->my_string_string_map = val;
+__isset.my_string_string_map = true;
+}
+
+void MegaStruct::__set_my_string_enum_map(const std::map<std::string, MyEnum::type> & val) {
+  this->my_string_enum_map = val;
+__isset.my_string_enum_map = true;
+}
+
+void MegaStruct::__set_my_enum_string_map(const std::map<MyEnum::type, std::string> & val) {
+  this->my_enum_string_map = val;
+__isset.my_enum_string_map = true;
+}
+
+void MegaStruct::__set_my_enum_struct_map(const std::map<MyEnum::type, MiniStruct> & val) {
+  this->my_enum_struct_map = val;
+__isset.my_enum_struct_map = true;
+}
+
+void MegaStruct::__set_my_enum_stringlist_map(const std::map<MyEnum::type, std::vector<std::string> > & val) {
+  this->my_enum_stringlist_map = val;
+__isset.my_enum_stringlist_map = true;
+}
+
+void MegaStruct::__set_my_enum_structlist_map(const std::map<MyEnum::type, std::vector<MiniStruct> > & val) {
+  this->my_enum_structlist_map = val;
+__isset.my_enum_structlist_map = true;
+}
+
+void MegaStruct::__set_my_stringlist(const std::vector<std::string> & val) {
+  this->my_stringlist = val;
+__isset.my_stringlist = true;
+}
+
+void MegaStruct::__set_my_structlist(const std::vector<MiniStruct> & val) {
+  this->my_structlist = val;
+__isset.my_structlist = true;
+}
+
+void MegaStruct::__set_my_enumlist(const std::vector<MyEnum::type> & val) {
+  this->my_enumlist = val;
+__isset.my_enumlist = true;
+}
+
+void MegaStruct::__set_my_stringset(const std::set<std::string> & val) {
+  this->my_stringset = val;
+__isset.my_stringset = true;
+}
+
+void MegaStruct::__set_my_enumset(const std::set<MyEnum::type> & val) {
+  this->my_enumset = val;
+__isset.my_enumset = true;
+}
+
+void MegaStruct::__set_my_structset(const std::set<MiniStruct> & val) {
+  this->my_structset = val;
+__isset.my_structset = true;
+}
+
 const char* MegaStruct::ascii_fingerprint = "9979EEF0CA19988228E64220A3AA9120";
 const uint8_t MegaStruct::binary_fingerprint[16] = {0x99,0x79,0xEE,0xF0,0xCA,0x19,0x98,0x82,0x28,0xE6,0x42,0x20,0xA3,0xAA,0x91,0x20};
 
@@ -190,17 +335,17 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_string_string_map.clear();
-            uint32_t _size1;
-            ::apache::thrift::protocol::TType _ktype2;
-            ::apache::thrift::protocol::TType _vtype3;
-            xfer += iprot->readMapBegin(_ktype2, _vtype3, _size1);
-            uint32_t _i5;
-            for (_i5 = 0; _i5 < _size1; ++_i5)
+            uint32_t _size3;
+            ::apache::thrift::protocol::TType _ktype4;
+            ::apache::thrift::protocol::TType _vtype5;
+            xfer += iprot->readMapBegin(_ktype4, _vtype5, _size3);
+            uint32_t _i7;
+            for (_i7 = 0; _i7 < _size3; ++_i7)
             {
-              std::string _key6;
-              xfer += iprot->readString(_key6);
-              std::string& _val7 = this->my_string_string_map[_key6];
-              xfer += iprot->readString(_val7);
+              std::string _key8;
+              xfer += iprot->readString(_key8);
+              std::string& _val9 = this->my_string_string_map[_key8];
+              xfer += iprot->readString(_val9);
             }
             xfer += iprot->readMapEnd();
           }
@@ -213,19 +358,19 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_string_enum_map.clear();
-            uint32_t _size8;
-            ::apache::thrift::protocol::TType _ktype9;
-            ::apache::thrift::protocol::TType _vtype10;
-            xfer += iprot->readMapBegin(_ktype9, _vtype10, _size8);
-            uint32_t _i12;
-            for (_i12 = 0; _i12 < _size8; ++_i12)
+            uint32_t _size10;
+            ::apache::thrift::protocol::TType _ktype11;
+            ::apache::thrift::protocol::TType _vtype12;
+            xfer += iprot->readMapBegin(_ktype11, _vtype12, _size10);
+            uint32_t _i14;
+            for (_i14 = 0; _i14 < _size10; ++_i14)
             {
-              std::string _key13;
-              xfer += iprot->readString(_key13);
-              MyEnum::type& _val14 = this->my_string_enum_map[_key13];
-              int32_t ecast15;
-              xfer += iprot->readI32(ecast15);
-              _val14 = (MyEnum::type)ecast15;
+              std::string _key15;
+              xfer += iprot->readString(_key15);
+              MyEnum::type& _val16 = this->my_string_enum_map[_key15];
+              int32_t ecast17;
+              xfer += iprot->readI32(ecast17);
+              _val16 = (MyEnum::type)ecast17;
             }
             xfer += iprot->readMapEnd();
           }
@@ -238,19 +383,19 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_enum_string_map.clear();
-            uint32_t _size16;
-            ::apache::thrift::protocol::TType _ktype17;
-            ::apache::thrift::protocol::TType _vtype18;
-            xfer += iprot->readMapBegin(_ktype17, _vtype18, _size16);
-            uint32_t _i20;
-            for (_i20 = 0; _i20 < _size16; ++_i20)
+            uint32_t _size18;
+            ::apache::thrift::protocol::TType _ktype19;
+            ::apache::thrift::protocol::TType _vtype20;
+            xfer += iprot->readMapBegin(_ktype19, _vtype20, _size18);
+            uint32_t _i22;
+            for (_i22 = 0; _i22 < _size18; ++_i22)
             {
-              MyEnum::type _key21;
-              int32_t ecast23;
-              xfer += iprot->readI32(ecast23);
-              _key21 = (MyEnum::type)ecast23;
-              std::string& _val22 = this->my_enum_string_map[_key21];
-              xfer += iprot->readString(_val22);
+              MyEnum::type _key23;
+              int32_t ecast25;
+              xfer += iprot->readI32(ecast25);
+              _key23 = (MyEnum::type)ecast25;
+              std::string& _val24 = this->my_enum_string_map[_key23];
+              xfer += iprot->readString(_val24);
             }
             xfer += iprot->readMapEnd();
           }
@@ -263,19 +408,19 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_enum_struct_map.clear();
-            uint32_t _size24;
-            ::apache::thrift::protocol::TType _ktype25;
-            ::apache::thrift::protocol::TType _vtype26;
-            xfer += iprot->readMapBegin(_ktype25, _vtype26, _size24);
-            uint32_t _i28;
-            for (_i28 = 0; _i28 < _size24; ++_i28)
+            uint32_t _size26;
+            ::apache::thrift::protocol::TType _ktype27;
+            ::apache::thrift::protocol::TType _vtype28;
+            xfer += iprot->readMapBegin(_ktype27, _vtype28, _size26);
+            uint32_t _i30;
+            for (_i30 = 0; _i30 < _size26; ++_i30)
             {
-              MyEnum::type _key29;
-              int32_t ecast31;
-              xfer += iprot->readI32(ecast31);
-              _key29 = (MyEnum::type)ecast31;
-              MiniStruct& _val30 = this->my_enum_struct_map[_key29];
-              xfer += _val30.read(iprot);
+              MyEnum::type _key31;
+              int32_t ecast33;
+              xfer += iprot->readI32(ecast33);
+              _key31 = (MyEnum::type)ecast33;
+              MiniStruct& _val32 = this->my_enum_struct_map[_key31];
+              xfer += _val32.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -288,28 +433,28 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_enum_stringlist_map.clear();
-            uint32_t _size32;
-            ::apache::thrift::protocol::TType _ktype33;
-            ::apache::thrift::protocol::TType _vtype34;
-            xfer += iprot->readMapBegin(_ktype33, _vtype34, _size32);
-            uint32_t _i36;
-            for (_i36 = 0; _i36 < _size32; ++_i36)
+            uint32_t _size34;
+            ::apache::thrift::protocol::TType _ktype35;
+            ::apache::thrift::protocol::TType _vtype36;
+            xfer += iprot->readMapBegin(_ktype35, _vtype36, _size34);
+            uint32_t _i38;
+            for (_i38 = 0; _i38 < _size34; ++_i38)
             {
-              MyEnum::type _key37;
-              int32_t ecast39;
-              xfer += iprot->readI32(ecast39);
-              _key37 = (MyEnum::type)ecast39;
-              std::vector<std::string> & _val38 = this->my_enum_stringlist_map[_key37];
+              MyEnum::type _key39;
+              int32_t ecast41;
+              xfer += iprot->readI32(ecast41);
+              _key39 = (MyEnum::type)ecast41;
+              std::vector<std::string> & _val40 = this->my_enum_stringlist_map[_key39];
               {
-                _val38.clear();
-                uint32_t _size40;
-                ::apache::thrift::protocol::TType _etype43;
-                xfer += iprot->readListBegin(_etype43, _size40);
-                _val38.resize(_size40);
-                uint32_t _i44;
-                for (_i44 = 0; _i44 < _size40; ++_i44)
+                _val40.clear();
+                uint32_t _size42;
+                ::apache::thrift::protocol::TType _etype45;
+                xfer += iprot->readListBegin(_etype45, _size42);
+                _val40.resize(_size42);
+                uint32_t _i46;
+                for (_i46 = 0; _i46 < _size42; ++_i46)
                 {
-                  xfer += iprot->readString(_val38[_i44]);
+                  xfer += iprot->readString(_val40[_i46]);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -325,28 +470,28 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->my_enum_structlist_map.clear();
-            uint32_t _size45;
-            ::apache::thrift::protocol::TType _ktype46;
-            ::apache::thrift::protocol::TType _vtype47;
-            xfer += iprot->readMapBegin(_ktype46, _vtype47, _size45);
-            uint32_t _i49;
-            for (_i49 = 0; _i49 < _size45; ++_i49)
+            uint32_t _size47;
+            ::apache::thrift::protocol::TType _ktype48;
+            ::apache::thrift::protocol::TType _vtype49;
+            xfer += iprot->readMapBegin(_ktype48, _vtype49, _size47);
+            uint32_t _i51;
+            for (_i51 = 0; _i51 < _size47; ++_i51)
             {
-              MyEnum::type _key50;
-              int32_t ecast52;
-              xfer += iprot->readI32(ecast52);
-              _key50 = (MyEnum::type)ecast52;
-              std::vector<MiniStruct> & _val51 = this->my_enum_structlist_map[_key50];
+              MyEnum::type _key52;
+              int32_t ecast54;
+              xfer += iprot->readI32(ecast54);
+              _key52 = (MyEnum::type)ecast54;
+              std::vector<MiniStruct> & _val53 = this->my_enum_structlist_map[_key52];
               {
-                _val51.clear();
-                uint32_t _size53;
-                ::apache::thrift::protocol::TType _etype56;
-                xfer += iprot->readListBegin(_etype56, _size53);
-                _val51.resize(_size53);
-                uint32_t _i57;
-                for (_i57 = 0; _i57 < _size53; ++_i57)
+                _val53.clear();
+                uint32_t _size55;
+                ::apache::thrift::protocol::TType _etype58;
+                xfer += iprot->readListBegin(_etype58, _size55);
+                _val53.resize(_size55);
+                uint32_t _i59;
+                for (_i59 = 0; _i59 < _size55; ++_i59)
                 {
-                  xfer += _val51[_i57].read(iprot);
+                  xfer += _val53[_i59].read(iprot);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -362,14 +507,14 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->my_stringlist.clear();
-            uint32_t _size58;
-            ::apache::thrift::protocol::TType _etype61;
-            xfer += iprot->readListBegin(_etype61, _size58);
-            this->my_stringlist.resize(_size58);
-            uint32_t _i62;
-            for (_i62 = 0; _i62 < _size58; ++_i62)
+            uint32_t _size60;
+            ::apache::thrift::protocol::TType _etype63;
+            xfer += iprot->readListBegin(_etype63, _size60);
+            this->my_stringlist.resize(_size60);
+            uint32_t _i64;
+            for (_i64 = 0; _i64 < _size60; ++_i64)
             {
-              xfer += iprot->readString(this->my_stringlist[_i62]);
+              xfer += iprot->readString(this->my_stringlist[_i64]);
             }
             xfer += iprot->readListEnd();
           }
@@ -382,14 +527,14 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->my_structlist.clear();
-            uint32_t _size63;
-            ::apache::thrift::protocol::TType _etype66;
-            xfer += iprot->readListBegin(_etype66, _size63);
-            this->my_structlist.resize(_size63);
-            uint32_t _i67;
-            for (_i67 = 0; _i67 < _size63; ++_i67)
+            uint32_t _size65;
+            ::apache::thrift::protocol::TType _etype68;
+            xfer += iprot->readListBegin(_etype68, _size65);
+            this->my_structlist.resize(_size65);
+            uint32_t _i69;
+            for (_i69 = 0; _i69 < _size65; ++_i69)
             {
-              xfer += this->my_structlist[_i67].read(iprot);
+              xfer += this->my_structlist[_i69].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -402,16 +547,16 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->my_enumlist.clear();
-            uint32_t _size68;
-            ::apache::thrift::protocol::TType _etype71;
-            xfer += iprot->readListBegin(_etype71, _size68);
-            this->my_enumlist.resize(_size68);
-            uint32_t _i72;
-            for (_i72 = 0; _i72 < _size68; ++_i72)
+            uint32_t _size70;
+            ::apache::thrift::protocol::TType _etype73;
+            xfer += iprot->readListBegin(_etype73, _size70);
+            this->my_enumlist.resize(_size70);
+            uint32_t _i74;
+            for (_i74 = 0; _i74 < _size70; ++_i74)
             {
-              int32_t ecast73;
-              xfer += iprot->readI32(ecast73);
-              this->my_enumlist[_i72] = (MyEnum::type)ecast73;
+              int32_t ecast75;
+              xfer += iprot->readI32(ecast75);
+              this->my_enumlist[_i74] = (MyEnum::type)ecast75;
             }
             xfer += iprot->readListEnd();
           }
@@ -424,15 +569,15 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_SET) {
           {
             this->my_stringset.clear();
-            uint32_t _size74;
-            ::apache::thrift::protocol::TType _etype77;
-            xfer += iprot->readSetBegin(_etype77, _size74);
-            uint32_t _i78;
-            for (_i78 = 0; _i78 < _size74; ++_i78)
+            uint32_t _size76;
+            ::apache::thrift::protocol::TType _etype79;
+            xfer += iprot->readSetBegin(_etype79, _size76);
+            uint32_t _i80;
+            for (_i80 = 0; _i80 < _size76; ++_i80)
             {
-              std::string _elem79;
-              xfer += iprot->readString(_elem79);
-              this->my_stringset.insert(_elem79);
+              std::string _elem81;
+              xfer += iprot->readString(_elem81);
+              this->my_stringset.insert(_elem81);
             }
             xfer += iprot->readSetEnd();
           }
@@ -445,17 +590,17 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_SET) {
           {
             this->my_enumset.clear();
-            uint32_t _size80;
-            ::apache::thrift::protocol::TType _etype83;
-            xfer += iprot->readSetBegin(_etype83, _size80);
-            uint32_t _i84;
-            for (_i84 = 0; _i84 < _size80; ++_i84)
+            uint32_t _size82;
+            ::apache::thrift::protocol::TType _etype85;
+            xfer += iprot->readSetBegin(_etype85, _size82);
+            uint32_t _i86;
+            for (_i86 = 0; _i86 < _size82; ++_i86)
             {
-              MyEnum::type _elem85;
-              int32_t ecast86;
-              xfer += iprot->readI32(ecast86);
-              _elem85 = (MyEnum::type)ecast86;
-              this->my_enumset.insert(_elem85);
+              MyEnum::type _elem87;
+              int32_t ecast88;
+              xfer += iprot->readI32(ecast88);
+              _elem87 = (MyEnum::type)ecast88;
+              this->my_enumset.insert(_elem87);
             }
             xfer += iprot->readSetEnd();
           }
@@ -468,15 +613,15 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_SET) {
           {
             this->my_structset.clear();
-            uint32_t _size87;
-            ::apache::thrift::protocol::TType _etype90;
-            xfer += iprot->readSetBegin(_etype90, _size87);
-            uint32_t _i91;
-            for (_i91 = 0; _i91 < _size87; ++_i91)
+            uint32_t _size89;
+            ::apache::thrift::protocol::TType _etype92;
+            xfer += iprot->readSetBegin(_etype92, _size89);
+            uint32_t _i93;
+            for (_i93 = 0; _i93 < _size89; ++_i93)
             {
-              MiniStruct _elem92;
-              xfer += _elem92.read(iprot);
-              this->my_structset.insert(_elem92);
+              MiniStruct _elem94;
+              xfer += _elem94.read(iprot);
+              this->my_structset.insert(_elem94);
             }
             xfer += iprot->readSetEnd();
           }
@@ -499,6 +644,7 @@ uint32_t MegaStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("MegaStruct");
 
   if (this->__isset.my_bool) {
@@ -545,11 +691,11 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_string_string_map", ::apache::thrift::protocol::T_MAP, 9);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->my_string_string_map.size()));
-      std::map<std::string, std::string> ::const_iterator _iter93;
-      for (_iter93 = this->my_string_string_map.begin(); _iter93 != this->my_string_string_map.end(); ++_iter93)
+      std::map<std::string, std::string> ::const_iterator _iter95;
+      for (_iter95 = this->my_string_string_map.begin(); _iter95 != this->my_string_string_map.end(); ++_iter95)
       {
-        xfer += oprot->writeString(_iter93->first);
-        xfer += oprot->writeString(_iter93->second);
+        xfer += oprot->writeString(_iter95->first);
+        xfer += oprot->writeString(_iter95->second);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -559,11 +705,11 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_string_enum_map", ::apache::thrift::protocol::T_MAP, 10);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->my_string_enum_map.size()));
-      std::map<std::string, MyEnum::type> ::const_iterator _iter94;
-      for (_iter94 = this->my_string_enum_map.begin(); _iter94 != this->my_string_enum_map.end(); ++_iter94)
+      std::map<std::string, MyEnum::type> ::const_iterator _iter96;
+      for (_iter96 = this->my_string_enum_map.begin(); _iter96 != this->my_string_enum_map.end(); ++_iter96)
       {
-        xfer += oprot->writeString(_iter94->first);
-        xfer += oprot->writeI32((int32_t)_iter94->second);
+        xfer += oprot->writeString(_iter96->first);
+        xfer += oprot->writeI32((int32_t)_iter96->second);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -573,11 +719,11 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enum_string_map", ::apache::thrift::protocol::T_MAP, 11);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I32, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->my_enum_string_map.size()));
-      std::map<MyEnum::type, std::string> ::const_iterator _iter95;
-      for (_iter95 = this->my_enum_string_map.begin(); _iter95 != this->my_enum_string_map.end(); ++_iter95)
+      std::map<MyEnum::type, std::string> ::const_iterator _iter97;
+      for (_iter97 = this->my_enum_string_map.begin(); _iter97 != this->my_enum_string_map.end(); ++_iter97)
       {
-        xfer += oprot->writeI32((int32_t)_iter95->first);
-        xfer += oprot->writeString(_iter95->second);
+        xfer += oprot->writeI32((int32_t)_iter97->first);
+        xfer += oprot->writeString(_iter97->second);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -587,11 +733,11 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enum_struct_map", ::apache::thrift::protocol::T_MAP, 12);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I32, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->my_enum_struct_map.size()));
-      std::map<MyEnum::type, MiniStruct> ::const_iterator _iter96;
-      for (_iter96 = this->my_enum_struct_map.begin(); _iter96 != this->my_enum_struct_map.end(); ++_iter96)
+      std::map<MyEnum::type, MiniStruct> ::const_iterator _iter98;
+      for (_iter98 = this->my_enum_struct_map.begin(); _iter98 != this->my_enum_struct_map.end(); ++_iter98)
       {
-        xfer += oprot->writeI32((int32_t)_iter96->first);
-        xfer += _iter96->second.write(oprot);
+        xfer += oprot->writeI32((int32_t)_iter98->first);
+        xfer += _iter98->second.write(oprot);
       }
       xfer += oprot->writeMapEnd();
     }
@@ -601,16 +747,16 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enum_stringlist_map", ::apache::thrift::protocol::T_MAP, 13);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I32, ::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->my_enum_stringlist_map.size()));
-      std::map<MyEnum::type, std::vector<std::string> > ::const_iterator _iter97;
-      for (_iter97 = this->my_enum_stringlist_map.begin(); _iter97 != this->my_enum_stringlist_map.end(); ++_iter97)
+      std::map<MyEnum::type, std::vector<std::string> > ::const_iterator _iter99;
+      for (_iter99 = this->my_enum_stringlist_map.begin(); _iter99 != this->my_enum_stringlist_map.end(); ++_iter99)
       {
-        xfer += oprot->writeI32((int32_t)_iter97->first);
+        xfer += oprot->writeI32((int32_t)_iter99->first);
         {
-          xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(_iter97->second.size()));
-          std::vector<std::string> ::const_iterator _iter98;
-          for (_iter98 = _iter97->second.begin(); _iter98 != _iter97->second.end(); ++_iter98)
+          xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(_iter99->second.size()));
+          std::vector<std::string> ::const_iterator _iter100;
+          for (_iter100 = _iter99->second.begin(); _iter100 != _iter99->second.end(); ++_iter100)
           {
-            xfer += oprot->writeString((*_iter98));
+            xfer += oprot->writeString((*_iter100));
           }
           xfer += oprot->writeListEnd();
         }
@@ -623,16 +769,16 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enum_structlist_map", ::apache::thrift::protocol::T_MAP, 14);
     {
       xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_I32, ::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->my_enum_structlist_map.size()));
-      std::map<MyEnum::type, std::vector<MiniStruct> > ::const_iterator _iter99;
-      for (_iter99 = this->my_enum_structlist_map.begin(); _iter99 != this->my_enum_structlist_map.end(); ++_iter99)
+      std::map<MyEnum::type, std::vector<MiniStruct> > ::const_iterator _iter101;
+      for (_iter101 = this->my_enum_structlist_map.begin(); _iter101 != this->my_enum_structlist_map.end(); ++_iter101)
       {
-        xfer += oprot->writeI32((int32_t)_iter99->first);
+        xfer += oprot->writeI32((int32_t)_iter101->first);
         {
-          xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter99->second.size()));
-          std::vector<MiniStruct> ::const_iterator _iter100;
-          for (_iter100 = _iter99->second.begin(); _iter100 != _iter99->second.end(); ++_iter100)
+          xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter101->second.size()));
+          std::vector<MiniStruct> ::const_iterator _iter102;
+          for (_iter102 = _iter101->second.begin(); _iter102 != _iter101->second.end(); ++_iter102)
           {
-            xfer += (*_iter100).write(oprot);
+            xfer += (*_iter102).write(oprot);
           }
           xfer += oprot->writeListEnd();
         }
@@ -645,10 +791,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_stringlist", ::apache::thrift::protocol::T_LIST, 15);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->my_stringlist.size()));
-      std::vector<std::string> ::const_iterator _iter101;
-      for (_iter101 = this->my_stringlist.begin(); _iter101 != this->my_stringlist.end(); ++_iter101)
+      std::vector<std::string> ::const_iterator _iter103;
+      for (_iter103 = this->my_stringlist.begin(); _iter103 != this->my_stringlist.end(); ++_iter103)
       {
-        xfer += oprot->writeString((*_iter101));
+        xfer += oprot->writeString((*_iter103));
       }
       xfer += oprot->writeListEnd();
     }
@@ -658,10 +804,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_structlist", ::apache::thrift::protocol::T_LIST, 16);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->my_structlist.size()));
-      std::vector<MiniStruct> ::const_iterator _iter102;
-      for (_iter102 = this->my_structlist.begin(); _iter102 != this->my_structlist.end(); ++_iter102)
+      std::vector<MiniStruct> ::const_iterator _iter104;
+      for (_iter104 = this->my_structlist.begin(); _iter104 != this->my_structlist.end(); ++_iter104)
       {
-        xfer += (*_iter102).write(oprot);
+        xfer += (*_iter104).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -671,10 +817,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enumlist", ::apache::thrift::protocol::T_LIST, 17);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->my_enumlist.size()));
-      std::vector<MyEnum::type> ::const_iterator _iter103;
-      for (_iter103 = this->my_enumlist.begin(); _iter103 != this->my_enumlist.end(); ++_iter103)
+      std::vector<MyEnum::type> ::const_iterator _iter105;
+      for (_iter105 = this->my_enumlist.begin(); _iter105 != this->my_enumlist.end(); ++_iter105)
       {
-        xfer += oprot->writeI32((int32_t)(*_iter103));
+        xfer += oprot->writeI32((int32_t)(*_iter105));
       }
       xfer += oprot->writeListEnd();
     }
@@ -684,10 +830,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_stringset", ::apache::thrift::protocol::T_SET, 18);
     {
       xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->my_stringset.size()));
-      std::set<std::string> ::const_iterator _iter104;
-      for (_iter104 = this->my_stringset.begin(); _iter104 != this->my_stringset.end(); ++_iter104)
+      std::set<std::string> ::const_iterator _iter106;
+      for (_iter106 = this->my_stringset.begin(); _iter106 != this->my_stringset.end(); ++_iter106)
       {
-        xfer += oprot->writeString((*_iter104));
+        xfer += oprot->writeString((*_iter106));
       }
       xfer += oprot->writeSetEnd();
     }
@@ -697,10 +843,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_enumset", ::apache::thrift::protocol::T_SET, 19);
     {
       xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->my_enumset.size()));
-      std::set<MyEnum::type> ::const_iterator _iter105;
-      for (_iter105 = this->my_enumset.begin(); _iter105 != this->my_enumset.end(); ++_iter105)
+      std::set<MyEnum::type> ::const_iterator _iter107;
+      for (_iter107 = this->my_enumset.begin(); _iter107 != this->my_enumset.end(); ++_iter107)
       {
-        xfer += oprot->writeI32((int32_t)(*_iter105));
+        xfer += oprot->writeI32((int32_t)(*_iter107));
       }
       xfer += oprot->writeSetEnd();
     }
@@ -710,10 +856,10 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("my_structset", ::apache::thrift::protocol::T_SET, 20);
     {
       xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->my_structset.size()));
-      std::set<MiniStruct> ::const_iterator _iter106;
-      for (_iter106 = this->my_structset.begin(); _iter106 != this->my_structset.end(); ++_iter106)
+      std::set<MiniStruct> ::const_iterator _iter108;
+      for (_iter108 = this->my_structset.begin(); _iter108 != this->my_structset.end(); ++_iter108)
       {
-        xfer += (*_iter106).write(oprot);
+        xfer += (*_iter108).write(oprot);
       }
       xfer += oprot->writeSetEnd();
     }
@@ -721,6 +867,7 @@ uint32_t MegaStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -749,4 +896,78 @@ void swap(MegaStruct &a, MegaStruct &b) {
   swap(a.__isset, b.__isset);
 }
 
+MegaStruct::MegaStruct(const MegaStruct& other109) {
+  my_bool = other109.my_bool;
+  my_byte = other109.my_byte;
+  my_16bit_int = other109.my_16bit_int;
+  my_32bit_int = other109.my_32bit_int;
+  my_64bit_int = other109.my_64bit_int;
+  my_double = other109.my_double;
+  my_string = other109.my_string;
+  my_binary = other109.my_binary;
+  my_string_string_map = other109.my_string_string_map;
+  my_string_enum_map = other109.my_string_enum_map;
+  my_enum_string_map = other109.my_enum_string_map;
+  my_enum_struct_map = other109.my_enum_struct_map;
+  my_enum_stringlist_map = other109.my_enum_stringlist_map;
+  my_enum_structlist_map = other109.my_enum_structlist_map;
+  my_stringlist = other109.my_stringlist;
+  my_structlist = other109.my_structlist;
+  my_enumlist = other109.my_enumlist;
+  my_stringset = other109.my_stringset;
+  my_enumset = other109.my_enumset;
+  my_structset = other109.my_structset;
+  __isset = other109.__isset;
+}
+MegaStruct& MegaStruct::operator=(const MegaStruct& other110) {
+  my_bool = other110.my_bool;
+  my_byte = other110.my_byte;
+  my_16bit_int = other110.my_16bit_int;
+  my_32bit_int = other110.my_32bit_int;
+  my_64bit_int = other110.my_64bit_int;
+  my_double = other110.my_double;
+  my_string = other110.my_string;
+  my_binary = other110.my_binary;
+  my_string_string_map = other110.my_string_string_map;
+  my_string_enum_map = other110.my_string_enum_map;
+  my_enum_string_map = other110.my_enum_string_map;
+  my_enum_struct_map = other110.my_enum_struct_map;
+  my_enum_stringlist_map = other110.my_enum_stringlist_map;
+  my_enum_structlist_map = other110.my_enum_structlist_map;
+  my_stringlist = other110.my_stringlist;
+  my_structlist = other110.my_structlist;
+  my_enumlist = other110.my_enumlist;
+  my_stringset = other110.my_stringset;
+  my_enumset = other110.my_enumset;
+  my_structset = other110.my_structset;
+  __isset = other110.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const MegaStruct& obj) {
+  using apache::thrift::to_string;
+  out << "MegaStruct(";
+  out << "my_bool="; (obj.__isset.my_bool ? (out << to_string(obj.my_bool)) : (out << "<null>"));
+  out << ", " << "my_byte="; (obj.__isset.my_byte ? (out << to_string(obj.my_byte)) : (out << "<null>"));
+  out << ", " << "my_16bit_int="; (obj.__isset.my_16bit_int ? (out << to_string(obj.my_16bit_int)) : (out << "<null>"));
+  out << ", " << "my_32bit_int="; (obj.__isset.my_32bit_int ? (out << to_string(obj.my_32bit_int)) : (out << "<null>"));
+  out << ", " << "my_64bit_int="; (obj.__isset.my_64bit_int ? (out << to_string(obj.my_64bit_int)) : (out << "<null>"));
+  out << ", " << "my_double="; (obj.__isset.my_double ? (out << to_string(obj.my_double)) : (out << "<null>"));
+  out << ", " << "my_string="; (obj.__isset.my_string ? (out << to_string(obj.my_string)) : (out << "<null>"));
+  out << ", " << "my_binary="; (obj.__isset.my_binary ? (out << to_string(obj.my_binary)) : (out << "<null>"));
+  out << ", " << "my_string_string_map="; (obj.__isset.my_string_string_map ? (out << to_string(obj.my_string_string_map)) : (out << "<null>"));
+  out << ", " << "my_string_enum_map="; (obj.__isset.my_string_enum_map ? (out << to_string(obj.my_string_enum_map)) : (out << "<null>"));
+  out << ", " << "my_enum_string_map="; (obj.__isset.my_enum_string_map ? (out << to_string(obj.my_enum_string_map)) : (out << "<null>"));
+  out << ", " << "my_enum_struct_map="; (obj.__isset.my_enum_struct_map ? (out << to_string(obj.my_enum_struct_map)) : (out << "<null>"));
+  out << ", " << "my_enum_stringlist_map="; (obj.__isset.my_enum_stringlist_map ? (out << to_string(obj.my_enum_stringlist_map)) : (out << "<null>"));
+  out << ", " << "my_enum_structlist_map="; (obj.__isset.my_enum_structlist_map ? (out << to_string(obj.my_enum_structlist_map)) : (out << "<null>"));
+  out << ", " << "my_stringlist="; (obj.__isset.my_stringlist ? (out << to_string(obj.my_stringlist)) : (out << "<null>"));
+  out << ", " << "my_structlist="; (obj.__isset.my_structlist ? (out << to_string(obj.my_structlist)) : (out << "<null>"));
+  out << ", " << "my_enumlist="; (obj.__isset.my_enumlist ? (out << to_string(obj.my_enumlist)) : (out << "<null>"));
+  out << ", " << "my_stringset="; (obj.__isset.my_stringset ? (out << to_string(obj.my_stringset)) : (out << "<null>"));
+  out << ", " << "my_enumset="; (obj.__isset.my_enumset ? (out << to_string(obj.my_enumset)) : (out << "<null>"));
+  out << ", " << "my_structset="; (obj.__isset.my_structset ? (out << to_string(obj.my_structset)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/megastruct_types.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/megastruct_types.h b/serde/src/gen/thrift/gen-cpp/megastruct_types.h
index b5a8295..e4985dc 100644
--- a/serde/src/gen/thrift/gen-cpp/megastruct_types.h
+++ b/serde/src/gen/thrift/gen-cpp/megastruct_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef megastruct_TYPES_H
 #define megastruct_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 
 
 
@@ -25,10 +28,14 @@ struct MyEnum {
 
 extern const std::map<int, const char*> _MyEnum_VALUES_TO_NAMES;
 
+class MiniStruct;
+
+class MegaStruct;
+
 typedef struct _MiniStruct__isset {
   _MiniStruct__isset() : my_string(false), my_enum(false) {}
-  bool my_string;
-  bool my_enum;
+  bool my_string :1;
+  bool my_enum :1;
 } _MiniStruct__isset;
 
 class MiniStruct {
@@ -37,25 +44,20 @@ class MiniStruct {
   static const char* ascii_fingerprint; // = "4ED2B10931906B61ED0B1592EE860A37";
   static const uint8_t binary_fingerprint[16]; // = {0x4E,0xD2,0xB1,0x09,0x31,0x90,0x6B,0x61,0xED,0x0B,0x15,0x92,0xEE,0x86,0x0A,0x37};
 
+  MiniStruct(const MiniStruct&);
+  MiniStruct& operator=(const MiniStruct&);
   MiniStruct() : my_string(), my_enum((MyEnum::type)0) {
   }
 
-  virtual ~MiniStruct() throw() {}
-
+  virtual ~MiniStruct() throw();
   std::string my_string;
   MyEnum::type my_enum;
 
   _MiniStruct__isset __isset;
 
-  void __set_my_string(const std::string& val) {
-    my_string = val;
-    __isset.my_string = true;
-  }
+  void __set_my_string(const std::string& val);
 
-  void __set_my_enum(const MyEnum::type val) {
-    my_enum = val;
-    __isset.my_enum = true;
-  }
+  void __set_my_enum(const MyEnum::type val);
 
   bool operator == (const MiniStruct & rhs) const
   {
@@ -78,32 +80,33 @@ class MiniStruct {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const MiniStruct& obj);
 };
 
 void swap(MiniStruct &a, MiniStruct &b);
 
 typedef struct _MegaStruct__isset {
   _MegaStruct__isset() : my_bool(false), my_byte(false), my_16bit_int(false), my_32bit_int(false), my_64bit_int(false), my_double(false), my_string(false), my_binary(false), my_string_string_map(false), my_string_enum_map(false), my_enum_string_map(false), my_enum_struct_map(false), my_enum_stringlist_map(false), my_enum_structlist_map(false), my_stringlist(false), my_structlist(false), my_enumlist(false), my_stringset(false), my_enumset(false), my_structset(false) {}
-  bool my_bool;
-  bool my_byte;
-  bool my_16bit_int;
-  bool my_32bit_int;
-  bool my_64bit_int;
-  bool my_double;
-  bool my_string;
-  bool my_binary;
-  bool my_string_string_map;
-  bool my_string_enum_map;
-  bool my_enum_string_map;
-  bool my_enum_struct_map;
-  bool my_enum_stringlist_map;
-  bool my_enum_structlist_map;
-  bool my_stringlist;
-  bool my_structlist;
-  bool my_enumlist;
-  bool my_stringset;
-  bool my_enumset;
-  bool my_structset;
+  bool my_bool :1;
+  bool my_byte :1;
+  bool my_16bit_int :1;
+  bool my_32bit_int :1;
+  bool my_64bit_int :1;
+  bool my_double :1;
+  bool my_string :1;
+  bool my_binary :1;
+  bool my_string_string_map :1;
+  bool my_string_enum_map :1;
+  bool my_enum_string_map :1;
+  bool my_enum_struct_map :1;
+  bool my_enum_stringlist_map :1;
+  bool my_enum_structlist_map :1;
+  bool my_stringlist :1;
+  bool my_structlist :1;
+  bool my_enumlist :1;
+  bool my_stringset :1;
+  bool my_enumset :1;
+  bool my_structset :1;
 } _MegaStruct__isset;
 
 class MegaStruct {
@@ -112,11 +115,12 @@ class MegaStruct {
   static const char* ascii_fingerprint; // = "9979EEF0CA19988228E64220A3AA9120";
   static const uint8_t binary_fingerprint[16]; // = {0x99,0x79,0xEE,0xF0,0xCA,0x19,0x98,0x82,0x28,0xE6,0x42,0x20,0xA3,0xAA,0x91,0x20};
 
+  MegaStruct(const MegaStruct&);
+  MegaStruct& operator=(const MegaStruct&);
   MegaStruct() : my_bool(0), my_byte(0), my_16bit_int(0), my_32bit_int(0), my_64bit_int(0), my_double(0), my_string(), my_binary() {
   }
 
-  virtual ~MegaStruct() throw() {}
-
+  virtual ~MegaStruct() throw();
   bool my_bool;
   int8_t my_byte;
   int16_t my_16bit_int;
@@ -140,105 +144,45 @@ class MegaStruct {
 
   _MegaStruct__isset __isset;
 
-  void __set_my_bool(const bool val) {
-    my_bool = val;
-    __isset.my_bool = true;
-  }
+  void __set_my_bool(const bool val);
 
-  void __set_my_byte(const int8_t val) {
-    my_byte = val;
-    __isset.my_byte = true;
-  }
+  void __set_my_byte(const int8_t val);
 
-  void __set_my_16bit_int(const int16_t val) {
-    my_16bit_int = val;
-    __isset.my_16bit_int = true;
-  }
+  void __set_my_16bit_int(const int16_t val);
 
-  void __set_my_32bit_int(const int32_t val) {
-    my_32bit_int = val;
-    __isset.my_32bit_int = true;
-  }
+  void __set_my_32bit_int(const int32_t val);
 
-  void __set_my_64bit_int(const int64_t val) {
-    my_64bit_int = val;
-    __isset.my_64bit_int = true;
-  }
+  void __set_my_64bit_int(const int64_t val);
 
-  void __set_my_double(const double val) {
-    my_double = val;
-    __isset.my_double = true;
-  }
+  void __set_my_double(const double val);
 
-  void __set_my_string(const std::string& val) {
-    my_string = val;
-    __isset.my_string = true;
-  }
+  void __set_my_string(const std::string& val);
 
-  void __set_my_binary(const std::string& val) {
-    my_binary = val;
-    __isset.my_binary = true;
-  }
+  void __set_my_binary(const std::string& val);
 
-  void __set_my_string_string_map(const std::map<std::string, std::string> & val) {
-    my_string_string_map = val;
-    __isset.my_string_string_map = true;
-  }
+  void __set_my_string_string_map(const std::map<std::string, std::string> & val);
 
-  void __set_my_string_enum_map(const std::map<std::string, MyEnum::type> & val) {
-    my_string_enum_map = val;
-    __isset.my_string_enum_map = true;
-  }
+  void __set_my_string_enum_map(const std::map<std::string, MyEnum::type> & val);
 
-  void __set_my_enum_string_map(const std::map<MyEnum::type, std::string> & val) {
-    my_enum_string_map = val;
-    __isset.my_enum_string_map = true;
-  }
+  void __set_my_enum_string_map(const std::map<MyEnum::type, std::string> & val);
 
-  void __set_my_enum_struct_map(const std::map<MyEnum::type, MiniStruct> & val) {
-    my_enum_struct_map = val;
-    __isset.my_enum_struct_map = true;
-  }
+  void __set_my_enum_struct_map(const std::map<MyEnum::type, MiniStruct> & val);
 
-  void __set_my_enum_stringlist_map(const std::map<MyEnum::type, std::vector<std::string> > & val) {
-    my_enum_stringlist_map = val;
-    __isset.my_enum_stringlist_map = true;
-  }
+  void __set_my_enum_stringlist_map(const std::map<MyEnum::type, std::vector<std::string> > & val);
 
-  void __set_my_enum_structlist_map(const std::map<MyEnum::type, std::vector<MiniStruct> > & val) {
-    my_enum_structlist_map = val;
-    __isset.my_enum_structlist_map = true;
-  }
+  void __set_my_enum_structlist_map(const std::map<MyEnum::type, std::vector<MiniStruct> > & val);
 
-  void __set_my_stringlist(const std::vector<std::string> & val) {
-    my_stringlist = val;
-    __isset.my_stringlist = true;
-  }
+  void __set_my_stringlist(const std::vector<std::string> & val);
 
-  void __set_my_structlist(const std::vector<MiniStruct> & val) {
-    my_structlist = val;
-    __isset.my_structlist = true;
-  }
+  void __set_my_structlist(const std::vector<MiniStruct> & val);
 
-  void __set_my_enumlist(const std::vector<MyEnum::type> & val) {
-    my_enumlist = val;
-    __isset.my_enumlist = true;
-  }
+  void __set_my_enumlist(const std::vector<MyEnum::type> & val);
 
-  void __set_my_stringset(const std::set<std::string> & val) {
-    my_stringset = val;
-    __isset.my_stringset = true;
-  }
+  void __set_my_stringset(const std::set<std::string> & val);
 
-  void __set_my_enumset(const std::set<MyEnum::type> & val) {
-    my_enumset = val;
-    __isset.my_enumset = true;
-  }
+  void __set_my_enumset(const std::set<MyEnum::type> & val);
 
-  void __set_my_structset(const std::set<MiniStruct> & val) {
-    my_structset = val;
-    __isset.my_structset = true;
-  }
+  void __set_my_structset(const std::set<MiniStruct> & val);
 
   bool operator == (const MegaStruct & rhs) const
   {
@@ -333,6 +277,7 @@ class MegaStruct {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const MegaStruct& obj);
 };
 
 void swap(MegaStruct &a, MegaStruct &b);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/serde_constants.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/serde_constants.cpp b/serde/src/gen/thrift/gen-cpp/serde_constants.cpp
index 5f8873b..196a46f 100644
--- a/serde/src/gen/thrift/gen-cpp/serde_constants.cpp
+++ b/serde/src/gen/thrift/gen-cpp/serde_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/serde_constants.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/serde_constants.h b/serde/src/gen/thrift/gen-cpp/serde_constants.h
index 4f2018b..36bd175 100644
--- a/serde/src/gen/thrift/gen-cpp/serde_constants.h
+++ b/serde/src/gen/thrift/gen-cpp/serde_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/serde_types.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/serde_types.cpp b/serde/src/gen/thrift/gen-cpp/serde_types.cpp
index 20d1fbd..a37ff7c 100644
--- a/serde/src/gen/thrift/gen-cpp/serde_types.cpp
+++ b/serde/src/gen/thrift/gen-cpp/serde_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "serde_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 namespace Hive {
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/serde_types.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/serde_types.h b/serde/src/gen/thrift/gen-cpp/serde_types.h
index 7fafa7d..eb7659a 100644
--- a/serde/src/gen/thrift/gen-cpp/serde_types.h
+++ b/serde/src/gen/thrift/gen-cpp/serde_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef serde_TYPES_H
 #define serde_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 
 
 namespace Hive {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/testthrift_constants.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/testthrift_constants.cpp b/serde/src/gen/thrift/gen-cpp/testthrift_constants.cpp
index 3dbbf1b..0fa57e7 100644
--- a/serde/src/gen/thrift/gen-cpp/testthrift_constants.cpp
+++ b/serde/src/gen/thrift/gen-cpp/testthrift_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/testthrift_constants.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/testthrift_constants.h b/serde/src/gen/thrift/gen-cpp/testthrift_constants.h
index 76e5f0c..cba3296 100644
--- a/serde/src/gen/thrift/gen-cpp/testthrift_constants.h
+++ b/serde/src/gen/thrift/gen-cpp/testthrift_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/testthrift_types.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/testthrift_types.cpp b/serde/src/gen/thrift/gen-cpp/testthrift_types.cpp
index 7949f23..0cd19b9 100644
--- a/serde/src/gen/thrift/gen-cpp/testthrift_types.cpp
+++ b/serde/src/gen/thrift/gen-cpp/testthrift_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,9 +7,21 @@
 #include "testthrift_types.h"
 
 #include <algorithm>
+#include <ostream>
 
+#include <thrift/TToString.h>
 
 
+
+
+InnerStruct::~InnerStruct() throw() {
+}
+
+
+void InnerStruct::__set_field0(const int32_t val) {
+  this->field0 = val;
+}
+
 const char* InnerStruct::ascii_fingerprint = "E86CACEB22240450EDCBEFC3A83970E4";
 const uint8_t InnerStruct::binary_fingerprint[16] = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
 
@@ -55,6 +67,7 @@ uint32_t InnerStruct::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t InnerStruct::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("InnerStruct");
 
   xfer += oprot->writeFieldBegin("field0", ::apache::thrift::protocol::T_I32, 1);
@@ -63,6 +76,7 @@ uint32_t InnerStruct::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -72,6 +86,40 @@ void swap(InnerStruct &a, InnerStruct &b) {
   swap(a.__isset, b.__isset);
 }
 
+InnerStruct::InnerStruct(const InnerStruct& other0) {
+  field0 = other0.field0;
+  __isset = other0.__isset;
+}
+InnerStruct& InnerStruct::operator=(const InnerStruct& other1) {
+  field0 = other1.field0;
+  __isset = other1.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const InnerStruct& obj) {
+  using apache::thrift::to_string;
+  out << "InnerStruct(";
+  out << "field0=" << to_string(obj.field0);
+  out << ")";
+  return out;
+}
+
+
+ThriftTestObj::~ThriftTestObj() throw() {
+}
+
+
+void ThriftTestObj::__set_field1(const int32_t val) {
+  this->field1 = val;
+}
+
+void ThriftTestObj::__set_field2(const std::string& val) {
+  this->field2 = val;
+}
+
+void ThriftTestObj::__set_field3(const std::vector<InnerStruct> & val) {
+  this->field3 = val;
+}
+
 const char* ThriftTestObj::ascii_fingerprint = "2BA5D8DAACFBBE6599779830A6185706";
 const uint8_t ThriftTestObj::binary_fingerprint[16] = {0x2B,0xA5,0xD8,0xDA,0xAC,0xFB,0xBE,0x65,0x99,0x77,0x98,0x30,0xA6,0x18,0x57,0x06};
 
@@ -115,14 +163,14 @@ uint32_t ThriftTestObj::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->field3.clear();
-            uint32_t _size0;
-            ::apache::thrift::protocol::TType _etype3;
-            xfer += iprot->readListBegin(_etype3, _size0);
-            this->field3.resize(_size0);
-            uint32_t _i4;
-            for (_i4 = 0; _i4 < _size0; ++_i4)
+            uint32_t _size2;
+            ::apache::thrift::protocol::TType _etype5;
+            xfer += iprot->readListBegin(_etype5, _size2);
+            this->field3.resize(_size2);
+            uint32_t _i6;
+            for (_i6 = 0; _i6 < _size2; ++_i6)
             {
-              xfer += this->field3[_i4].read(iprot);
+              xfer += this->field3[_i6].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -145,6 +193,7 @@ uint32_t ThriftTestObj::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t ThriftTestObj::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftTestObj");
 
   xfer += oprot->writeFieldBegin("field1", ::apache::thrift::protocol::T_I32, 1);
@@ -158,10 +207,10 @@ uint32_t ThriftTestObj::write(::apache::thrift::protocol::TProtocol* oprot) cons
   xfer += oprot->writeFieldBegin("field3", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->field3.size()));
-    std::vector<InnerStruct> ::const_iterator _iter5;
-    for (_iter5 = this->field3.begin(); _iter5 != this->field3.end(); ++_iter5)
+    std::vector<InnerStruct> ::const_iterator _iter7;
+    for (_iter7 = this->field3.begin(); _iter7 != this->field3.end(); ++_iter7)
     {
-      xfer += (*_iter5).write(oprot);
+      xfer += (*_iter7).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -169,6 +218,7 @@ uint32_t ThriftTestObj::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -180,4 +230,27 @@ void swap(ThriftTestObj &a, ThriftTestObj &b) {
   swap(a.__isset, b.__isset);
 }
 
+ThriftTestObj::ThriftTestObj(const ThriftTestObj& other8) {
+  field1 = other8.field1;
+  field2 = other8.field2;
+  field3 = other8.field3;
+  __isset = other8.__isset;
+}
+ThriftTestObj& ThriftTestObj::operator=(const ThriftTestObj& other9) {
+  field1 = other9.field1;
+  field2 = other9.field2;
+  field3 = other9.field3;
+  __isset = other9.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const ThriftTestObj& obj) {
+  using apache::thrift::to_string;
+  out << "ThriftTestObj(";
+  out << "field1=" << to_string(obj.field1);
+  out << ", " << "field2=" << to_string(obj.field2);
+  out << ", " << "field3=" << to_string(obj.field3);
+  out << ")";
+  return out;
+}
+
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/testthrift_types.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/testthrift_types.h b/serde/src/gen/thrift/gen-cpp/testthrift_types.h
index 6c84b9f..8c57e48 100644
--- a/serde/src/gen/thrift/gen-cpp/testthrift_types.h
+++ b/serde/src/gen/thrift/gen-cpp/testthrift_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,18 +7,25 @@
 #ifndef testthrift_TYPES_H
 #define testthrift_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
+
+
 
 
+class InnerStruct;
 
+class ThriftTestObj;
 
 typedef struct _InnerStruct__isset {
   _InnerStruct__isset() : field0(false) {}
-  bool field0;
+  bool field0 :1;
 } _InnerStruct__isset;
 
 class InnerStruct {
@@ -27,18 +34,17 @@ class InnerStruct {
   static const char* ascii_fingerprint; // = "E86CACEB22240450EDCBEFC3A83970E4";
   static const uint8_t binary_fingerprint[16]; // = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
 
+  InnerStruct(const InnerStruct&);
+  InnerStruct& operator=(const InnerStruct&);
   InnerStruct() : field0(0) {
   }
 
-  virtual ~InnerStruct() throw() {}
-
+  virtual ~InnerStruct() throw();
   int32_t field0;
 
   _InnerStruct__isset __isset;
 
-  void __set_field0(const int32_t val) {
-    field0 = val;
-  }
+  void __set_field0(const int32_t val);
 
   bool operator == (const InnerStruct & rhs) const
   {
@@ -55,15 +61,16 @@ class InnerStruct {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const InnerStruct& obj);
 };
 
 void swap(InnerStruct &a, InnerStruct &b);
 
 typedef struct _ThriftTestObj__isset {
   _ThriftTestObj__isset() : field1(false), field2(false), field3(false) {}
-  bool field1;
-  bool field2;
-  bool field3;
+  bool field1 :1;
+  bool field2 :1;
+  bool field3 :1;
 } _ThriftTestObj__isset;
 
 class ThriftTestObj {
@@ -72,28 +79,23 @@ class ThriftTestObj {
   static const char* ascii_fingerprint; // = "2BA5D8DAACFBBE6599779830A6185706";
   static const uint8_t binary_fingerprint[16]; // = {0x2B,0xA5,0xD8,0xDA,0xAC,0xFB,0xBE,0x65,0x99,0x77,0x98,0x30,0xA6,0x18,0x57,0x06};
 
+  ThriftTestObj(const ThriftTestObj&);
+  ThriftTestObj& operator=(const ThriftTestObj&);
   ThriftTestObj() : field1(0), field2() {
   }
 
-  virtual ~ThriftTestObj() throw() {}
-
+  virtual ~ThriftTestObj() throw();
   int32_t field1;
   std::string field2;
   std::vector<InnerStruct>  field3;
 
   _ThriftTestObj__isset __isset;
 
-  void __set_field1(const int32_t val) {
-    field1 = val;
-  }
+  void __set_field1(const int32_t val);
 
-  void __set_field2(const std::string& val) {
-    field2 = val;
-  }
+  void __set_field2(const std::string& val);
 
-  void __set_field3(const std::vector<InnerStruct> & val) {
-    field3 = val;
-  }
+  void __set_field3(const std::vector<InnerStruct> & val);
 
   bool operator == (const ThriftTestObj & rhs) const
   {
@@ -114,6 +116,7 @@ class ThriftTestObj {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftTestObj& obj);
 };
 
 void swap(ThriftTestObj &a, ThriftTestObj &b);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/serdeConstants.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/serdeConstants.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/serdeConstants.java
index 5f3001d..f12d4c7 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/serdeConstants.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/serdeConstants.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class serdeConstants {
 
   public static final String SERIALIZATION_LIB = "serialization.lib";

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/InnerStruct.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/InnerStruct.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/InnerStruct.java
index 72a28ae..37e228c 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/InnerStruct.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/InnerStruct.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InnerStruct implements org.apache.thrift.TBase<InnerStruct, InnerStruct._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InnerStruct implements org.apache.thrift.TBase<InnerStruct, InnerStruct._Fields>, java.io.Serializable, Cloneable, Comparable<InnerStruct> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InnerStruct");
 
   private static final org.apache.thrift.protocol.TField FIELD0_FIELD_DESC = new org.apache.thrift.protocol.TField("field0", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -227,30 +231,30 @@ public class InnerStruct implements org.apache.thrift.TBase<InnerStruct, InnerSt
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_field0 = true;
-    builder.append(present_field0);
+    list.add(present_field0);
     if (present_field0)
-      builder.append(field0);
+      list.add(field0);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InnerStruct other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InnerStruct typedOther = (InnerStruct)other;
 
-    lastComparison = Boolean.valueOf(isSetField0()).compareTo(typedOther.isSetField0());
+    lastComparison = Boolean.valueOf(isSetField0()).compareTo(other.isSetField0());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetField0()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field0, typedOther.field0);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field0, other.field0);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/ThriftTestObj.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/ThriftTestObj.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/ThriftTestObj.java
index dda3c5f..747e6e1 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/ThriftTestObj.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde/test/ThriftTestObj.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, ThriftTestObj._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, ThriftTestObj._Fields>, java.io.Serializable, Cloneable, Comparable<ThriftTestObj> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ThriftTestObj");
 
   private static final org.apache.thrift.protocol.TField FIELD1_FIELD_DESC = new org.apache.thrift.protocol.TField("field1", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -154,7 +158,7 @@ public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, Thr
       this.field2 = other.field2;
     }
     if (other.isSetField3()) {
-      List<InnerStruct> __this__field3 = new ArrayList<InnerStruct>();
+      List<InnerStruct> __this__field3 = new ArrayList<InnerStruct>(other.field3.size());
       for (InnerStruct other_element : other.field3) {
         __this__field3.add(new InnerStruct(other_element));
       }
@@ -363,60 +367,60 @@ public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, Thr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_field1 = true;
-    builder.append(present_field1);
+    list.add(present_field1);
     if (present_field1)
-      builder.append(field1);
+      list.add(field1);
 
     boolean present_field2 = true && (isSetField2());
-    builder.append(present_field2);
+    list.add(present_field2);
     if (present_field2)
-      builder.append(field2);
+      list.add(field2);
 
     boolean present_field3 = true && (isSetField3());
-    builder.append(present_field3);
+    list.add(present_field3);
     if (present_field3)
-      builder.append(field3);
+      list.add(field3);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ThriftTestObj other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ThriftTestObj typedOther = (ThriftTestObj)other;
 
-    lastComparison = Boolean.valueOf(isSetField1()).compareTo(typedOther.isSetField1());
+    lastComparison = Boolean.valueOf(isSetField1()).compareTo(other.isSetField1());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetField1()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field1, typedOther.field1);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field1, other.field1);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetField2()).compareTo(typedOther.isSetField2());
+    lastComparison = Boolean.valueOf(isSetField2()).compareTo(other.isSetField2());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetField2()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field2, typedOther.field2);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field2, other.field2);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetField3()).compareTo(typedOther.isSetField3());
+    lastComparison = Boolean.valueOf(isSetField3()).compareTo(other.isSetField3());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetField3()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field3, typedOther.field3);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.field3, other.field3);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -526,12 +530,12 @@ public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, Thr
               {
                 org.apache.thrift.protocol.TList _list0 = iprot.readListBegin();
                 struct.field3 = new ArrayList<InnerStruct>(_list0.size);
-                for (int _i1 = 0; _i1 < _list0.size; ++_i1)
+                InnerStruct _elem1;
+                for (int _i2 = 0; _i2 < _list0.size; ++_i2)
                 {
-                  InnerStruct _elem2; // optional
-                  _elem2 = new InnerStruct();
-                  _elem2.read(iprot);
-                  struct.field3.add(_elem2);
+                  _elem1 = new InnerStruct();
+                  _elem1.read(iprot);
+                  struct.field3.add(_elem1);
                 }
                 iprot.readListEnd();
               }
@@ -634,12 +638,12 @@ public class ThriftTestObj implements org.apache.thrift.TBase<ThriftTestObj, Thr
         {
           org.apache.thrift.protocol.TList _list5 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.field3 = new ArrayList<InnerStruct>(_list5.size);
-          for (int _i6 = 0; _i6 < _list5.size; ++_i6)
+          InnerStruct _elem6;
+          for (int _i7 = 0; _i7 < _list5.size; ++_i7)
           {
-            InnerStruct _elem7; // optional
-            _elem7 = new InnerStruct();
-            _elem7.read(iprot);
-            struct.field3.add(_elem7);
+            _elem6 = new InnerStruct();
+            _elem6.read(iprot);
+            struct.field3.add(_elem6);
           }
         }
         struct.setField3IsSet(true);


[03/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringColumn.java
index 3dae460..024ed36 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TStringColumn._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TStringColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TStringColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TStringColumn");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
    */
   public TStringColumn(TStringColumn other) {
     if (other.isSetValues()) {
-      List<String> __this__values = new ArrayList<String>();
-      for (String other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<String> __this__values = new ArrayList<String>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TStringColumn other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TStringColumn typedOther = (TStringColumn)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
               {
                 org.apache.thrift.protocol.TList _list102 = iprot.readListBegin();
                 struct.values = new ArrayList<String>(_list102.size);
-                for (int _i103 = 0; _i103 < _list102.size; ++_i103)
+                String _elem103;
+                for (int _i104 = 0; _i104 < _list102.size; ++_i104)
                 {
-                  String _elem104; // optional
-                  _elem104 = iprot.readString();
-                  struct.values.add(_elem104);
+                  _elem103 = iprot.readString();
+                  struct.values.add(_elem103);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TStringColumn implements org.apache.thrift.TBase<TStringColumn, TSt
       {
         org.apache.thrift.protocol.TList _list107 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.values = new ArrayList<String>(_list107.size);
-        for (int _i108 = 0; _i108 < _list107.size; ++_i108)
+        String _elem108;
+        for (int _i109 = 0; _i109 < _list107.size; ++_i109)
         {
-          String _elem109; // optional
-          _elem109 = iprot.readString();
-          struct.values.add(_elem109);
+          _elem108 = iprot.readString();
+          struct.values.add(_elem108);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringValue.java
index af7a109..bc7f121 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStringValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TStringValue implements org.apache.thrift.TBase<TStringValue, TStringValue._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TStringValue implements org.apache.thrift.TBase<TStringValue, TStringValue._Fields>, java.io.Serializable, Cloneable, Comparable<TStringValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TStringValue");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -103,7 +107,7 @@ public class TStringValue implements org.apache.thrift.TBase<TStringValue, TStri
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -219,30 +223,30 @@ public class TStringValue implements org.apache.thrift.TBase<TStringValue, TStri
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TStringValue other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TStringValue typedOther = (TStringValue)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStructTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStructTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStructTypeEntry.java
index 20f5fb6..ad95cce 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStructTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStructTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntry, TStructTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntry, TStructTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TStructTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TStructTypeEntry");
 
   private static final org.apache.thrift.protocol.TField NAME_TO_TYPE_PTR_FIELD_DESC = new org.apache.thrift.protocol.TField("nameToTypePtr", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -129,7 +133,7 @@ public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntr
    */
   public TStructTypeEntry(TStructTypeEntry other) {
     if (other.isSetNameToTypePtr()) {
-      Map<String,Integer> __this__nameToTypePtr = new HashMap<String,Integer>();
+      Map<String,Integer> __this__nameToTypePtr = new HashMap<String,Integer>(other.nameToTypePtr.size());
       for (Map.Entry<String, Integer> other_element : other.nameToTypePtr.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -250,30 +254,30 @@ public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_nameToTypePtr = true && (isSetNameToTypePtr());
-    builder.append(present_nameToTypePtr);
+    list.add(present_nameToTypePtr);
     if (present_nameToTypePtr)
-      builder.append(nameToTypePtr);
+      list.add(nameToTypePtr);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TStructTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TStructTypeEntry typedOther = (TStructTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetNameToTypePtr()).compareTo(typedOther.isSetNameToTypePtr());
+    lastComparison = Boolean.valueOf(isSetNameToTypePtr()).compareTo(other.isSetNameToTypePtr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNameToTypePtr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nameToTypePtr, typedOther.nameToTypePtr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nameToTypePtr, other.nameToTypePtr);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -357,13 +361,13 @@ public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntr
               {
                 org.apache.thrift.protocol.TMap _map10 = iprot.readMapBegin();
                 struct.nameToTypePtr = new HashMap<String,Integer>(2*_map10.size);
-                for (int _i11 = 0; _i11 < _map10.size; ++_i11)
+                String _key11;
+                int _val12;
+                for (int _i13 = 0; _i13 < _map10.size; ++_i13)
                 {
-                  String _key12; // required
-                  int _val13; // required
-                  _key12 = iprot.readString();
-                  _val13 = iprot.readI32();
-                  struct.nameToTypePtr.put(_key12, _val13);
+                  _key11 = iprot.readString();
+                  _val12 = iprot.readI32();
+                  struct.nameToTypePtr.put(_key11, _val12);
                 }
                 iprot.readMapEnd();
               }
@@ -431,13 +435,13 @@ public class TStructTypeEntry implements org.apache.thrift.TBase<TStructTypeEntr
       {
         org.apache.thrift.protocol.TMap _map16 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
         struct.nameToTypePtr = new HashMap<String,Integer>(2*_map16.size);
-        for (int _i17 = 0; _i17 < _map16.size; ++_i17)
+        String _key17;
+        int _val18;
+        for (int _i19 = 0; _i19 < _map16.size; ++_i19)
         {
-          String _key18; // required
-          int _val19; // required
-          _key18 = iprot.readString();
-          _val19 = iprot.readI32();
-          struct.nameToTypePtr.put(_key18, _val19);
+          _key17 = iprot.readString();
+          _val18 = iprot.readI32();
+          struct.nameToTypePtr.put(_key17, _val18);
         }
       }
       struct.setNameToTypePtrIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTableSchema.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTableSchema.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTableSchema.java
index ff5e54d..4416a07 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTableSchema.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTableSchema.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTableSchema._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTableSchema._Fields>, java.io.Serializable, Cloneable, Comparable<TTableSchema> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TTableSchema");
 
   private static final org.apache.thrift.protocol.TField COLUMNS_FIELD_DESC = new org.apache.thrift.protocol.TField("columns", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTabl
    */
   public TTableSchema(TTableSchema other) {
     if (other.isSetColumns()) {
-      List<TColumnDesc> __this__columns = new ArrayList<TColumnDesc>();
+      List<TColumnDesc> __this__columns = new ArrayList<TColumnDesc>(other.columns.size());
       for (TColumnDesc other_element : other.columns) {
         __this__columns.add(new TColumnDesc(other_element));
       }
@@ -245,30 +249,30 @@ public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTabl
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_columns = true && (isSetColumns());
-    builder.append(present_columns);
+    list.add(present_columns);
     if (present_columns)
-      builder.append(columns);
+      list.add(columns);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TTableSchema other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TTableSchema typedOther = (TTableSchema)other;
 
-    lastComparison = Boolean.valueOf(isSetColumns()).compareTo(typedOther.isSetColumns());
+    lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColumns()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, typedOther.columns);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTabl
               {
                 org.apache.thrift.protocol.TList _list38 = iprot.readListBegin();
                 struct.columns = new ArrayList<TColumnDesc>(_list38.size);
-                for (int _i39 = 0; _i39 < _list38.size; ++_i39)
+                TColumnDesc _elem39;
+                for (int _i40 = 0; _i40 < _list38.size; ++_i40)
                 {
-                  TColumnDesc _elem40; // optional
-                  _elem40 = new TColumnDesc();
-                  _elem40.read(iprot);
-                  struct.columns.add(_elem40);
+                  _elem39 = new TColumnDesc();
+                  _elem39.read(iprot);
+                  struct.columns.add(_elem39);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class TTableSchema implements org.apache.thrift.TBase<TTableSchema, TTabl
       {
         org.apache.thrift.protocol.TList _list43 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.columns = new ArrayList<TColumnDesc>(_list43.size);
-        for (int _i44 = 0; _i44 < _list43.size; ++_i44)
+        TColumnDesc _elem44;
+        for (int _i45 = 0; _i45 < _list43.size; ++_i45)
         {
-          TColumnDesc _elem45; // optional
-          _elem45 = new TColumnDesc();
-          _elem45.read(iprot);
-          struct.columns.add(_elem45);
+          _elem44 = new TColumnDesc();
+          _elem44.read(iprot);
+          struct.columns.add(_elem44);
         }
       }
       struct.setColumnsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeDesc.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeDesc.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeDesc.java
index 251f86a..a97c9aa 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeDesc.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeDesc.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._Fields>, java.io.Serializable, Cloneable, Comparable<TTypeDesc> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TTypeDesc");
 
   private static final org.apache.thrift.protocol.TField TYPES_FIELD_DESC = new org.apache.thrift.protocol.TField("types", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._
    */
   public TTypeDesc(TTypeDesc other) {
     if (other.isSetTypes()) {
-      List<TTypeEntry> __this__types = new ArrayList<TTypeEntry>();
+      List<TTypeEntry> __this__types = new ArrayList<TTypeEntry>(other.types.size());
       for (TTypeEntry other_element : other.types) {
         __this__types.add(new TTypeEntry(other_element));
       }
@@ -245,30 +249,30 @@ public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_types = true && (isSetTypes());
-    builder.append(present_types);
+    list.add(present_types);
     if (present_types)
-      builder.append(types);
+      list.add(types);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TTypeDesc other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TTypeDesc typedOther = (TTypeDesc)other;
 
-    lastComparison = Boolean.valueOf(isSetTypes()).compareTo(typedOther.isSetTypes());
+    lastComparison = Boolean.valueOf(isSetTypes()).compareTo(other.isSetTypes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTypes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.types, typedOther.types);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.types, other.types);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._
               {
                 org.apache.thrift.protocol.TList _list30 = iprot.readListBegin();
                 struct.types = new ArrayList<TTypeEntry>(_list30.size);
-                for (int _i31 = 0; _i31 < _list30.size; ++_i31)
+                TTypeEntry _elem31;
+                for (int _i32 = 0; _i32 < _list30.size; ++_i32)
                 {
-                  TTypeEntry _elem32; // optional
-                  _elem32 = new TTypeEntry();
-                  _elem32.read(iprot);
-                  struct.types.add(_elem32);
+                  _elem31 = new TTypeEntry();
+                  _elem31.read(iprot);
+                  struct.types.add(_elem31);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class TTypeDesc implements org.apache.thrift.TBase<TTypeDesc, TTypeDesc._
       {
         org.apache.thrift.protocol.TList _list35 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.types = new ArrayList<TTypeEntry>(_list35.size);
-        for (int _i36 = 0; _i36 < _list35.size; ++_i36)
+        TTypeEntry _elem36;
+        for (int _i37 = 0; _i37 < _list35.size; ++_i37)
         {
-          TTypeEntry _elem37; // optional
-          _elem37 = new TTypeEntry();
-          _elem37.read(iprot);
-          struct.types.add(_elem37);
+          _elem36 = new TTypeEntry();
+          _elem36.read(iprot);
+          struct.types.add(_elem36);
         }
       }
       struct.setTypesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeEntry.java
index af7c0b4..203d3b9 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TTypeEntry extends org.apache.thrift.TUnion<TTypeEntry, TTypeEntry._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TTypeEntry");
   private static final org.apache.thrift.protocol.TField PRIMITIVE_ENTRY_FIELD_DESC = new org.apache.thrift.protocol.TField("primitiveEntry", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -291,6 +294,7 @@ public class TTypeEntry extends org.apache.thrift.TUnion<TTypeEntry, TTypeEntry.
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -575,19 +579,19 @@ public class TTypeEntry extends org.apache.thrift.TUnion<TTypeEntry, TTypeEntry.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeId.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeId.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeId.java
index 40f0589..e6f2336 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeId.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeId.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifierValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifierValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifierValue.java
index 8c40687..54df6dc 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifierValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifierValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TTypeQualifierValue extends org.apache.thrift.TUnion<TTypeQualifierValue, TTypeQualifierValue._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TTypeQualifierValue");
   private static final org.apache.thrift.protocol.TField I32_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("i32Value", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -181,6 +184,7 @@ public class TTypeQualifierValue extends org.apache.thrift.TUnion<TTypeQualifier
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -326,19 +330,19 @@ public class TTypeQualifierValue extends org.apache.thrift.TUnion<TTypeQualifier
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifiers.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifiers.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifiers.java
index 3935555..7f5b1b3 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifiers.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TTypeQualifiers.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers, TTypeQualifiers._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers, TTypeQualifiers._Fields>, java.io.Serializable, Cloneable, Comparable<TTypeQualifiers> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TTypeQualifiers");
 
   private static final org.apache.thrift.protocol.TField QUALIFIERS_FIELD_DESC = new org.apache.thrift.protocol.TField("qualifiers", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -129,7 +133,7 @@ public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers,
    */
   public TTypeQualifiers(TTypeQualifiers other) {
     if (other.isSetQualifiers()) {
-      Map<String,TTypeQualifierValue> __this__qualifiers = new HashMap<String,TTypeQualifierValue>();
+      Map<String,TTypeQualifierValue> __this__qualifiers = new HashMap<String,TTypeQualifierValue>(other.qualifiers.size());
       for (Map.Entry<String, TTypeQualifierValue> other_element : other.qualifiers.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -250,30 +254,30 @@ public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_qualifiers = true && (isSetQualifiers());
-    builder.append(present_qualifiers);
+    list.add(present_qualifiers);
     if (present_qualifiers)
-      builder.append(qualifiers);
+      list.add(qualifiers);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TTypeQualifiers other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TTypeQualifiers typedOther = (TTypeQualifiers)other;
 
-    lastComparison = Boolean.valueOf(isSetQualifiers()).compareTo(typedOther.isSetQualifiers());
+    lastComparison = Boolean.valueOf(isSetQualifiers()).compareTo(other.isSetQualifiers());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQualifiers()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.qualifiers, typedOther.qualifiers);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.qualifiers, other.qualifiers);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -357,14 +361,14 @@ public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers,
               {
                 org.apache.thrift.protocol.TMap _map0 = iprot.readMapBegin();
                 struct.qualifiers = new HashMap<String,TTypeQualifierValue>(2*_map0.size);
-                for (int _i1 = 0; _i1 < _map0.size; ++_i1)
+                String _key1;
+                TTypeQualifierValue _val2;
+                for (int _i3 = 0; _i3 < _map0.size; ++_i3)
                 {
-                  String _key2; // required
-                  TTypeQualifierValue _val3; // required
-                  _key2 = iprot.readString();
-                  _val3 = new TTypeQualifierValue();
-                  _val3.read(iprot);
-                  struct.qualifiers.put(_key2, _val3);
+                  _key1 = iprot.readString();
+                  _val2 = new TTypeQualifierValue();
+                  _val2.read(iprot);
+                  struct.qualifiers.put(_key1, _val2);
                 }
                 iprot.readMapEnd();
               }
@@ -432,14 +436,14 @@ public class TTypeQualifiers implements org.apache.thrift.TBase<TTypeQualifiers,
       {
         org.apache.thrift.protocol.TMap _map6 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.qualifiers = new HashMap<String,TTypeQualifierValue>(2*_map6.size);
-        for (int _i7 = 0; _i7 < _map6.size; ++_i7)
+        String _key7;
+        TTypeQualifierValue _val8;
+        for (int _i9 = 0; _i9 < _map6.size; ++_i9)
         {
-          String _key8; // required
-          TTypeQualifierValue _val9; // required
-          _key8 = iprot.readString();
-          _val9 = new TTypeQualifierValue();
-          _val9.read(iprot);
-          struct.qualifiers.put(_key8, _val9);
+          _key7 = iprot.readString();
+          _val8 = new TTypeQualifierValue();
+          _val8.read(iprot);
+          struct.qualifiers.put(_key7, _val8);
         }
       }
       struct.setQualifiersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUnionTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUnionTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUnionTypeEntry.java
index 73dd45d..243b307 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUnionTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUnionTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry, TUnionTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry, TUnionTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TUnionTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TUnionTypeEntry");
 
   private static final org.apache.thrift.protocol.TField NAME_TO_TYPE_PTR_FIELD_DESC = new org.apache.thrift.protocol.TField("nameToTypePtr", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -129,7 +133,7 @@ public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry,
    */
   public TUnionTypeEntry(TUnionTypeEntry other) {
     if (other.isSetNameToTypePtr()) {
-      Map<String,Integer> __this__nameToTypePtr = new HashMap<String,Integer>();
+      Map<String,Integer> __this__nameToTypePtr = new HashMap<String,Integer>(other.nameToTypePtr.size());
       for (Map.Entry<String, Integer> other_element : other.nameToTypePtr.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -250,30 +254,30 @@ public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_nameToTypePtr = true && (isSetNameToTypePtr());
-    builder.append(present_nameToTypePtr);
+    list.add(present_nameToTypePtr);
     if (present_nameToTypePtr)
-      builder.append(nameToTypePtr);
+      list.add(nameToTypePtr);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TUnionTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TUnionTypeEntry typedOther = (TUnionTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetNameToTypePtr()).compareTo(typedOther.isSetNameToTypePtr());
+    lastComparison = Boolean.valueOf(isSetNameToTypePtr()).compareTo(other.isSetNameToTypePtr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNameToTypePtr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nameToTypePtr, typedOther.nameToTypePtr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nameToTypePtr, other.nameToTypePtr);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -357,13 +361,13 @@ public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry,
               {
                 org.apache.thrift.protocol.TMap _map20 = iprot.readMapBegin();
                 struct.nameToTypePtr = new HashMap<String,Integer>(2*_map20.size);
-                for (int _i21 = 0; _i21 < _map20.size; ++_i21)
+                String _key21;
+                int _val22;
+                for (int _i23 = 0; _i23 < _map20.size; ++_i23)
                 {
-                  String _key22; // required
-                  int _val23; // required
-                  _key22 = iprot.readString();
-                  _val23 = iprot.readI32();
-                  struct.nameToTypePtr.put(_key22, _val23);
+                  _key21 = iprot.readString();
+                  _val22 = iprot.readI32();
+                  struct.nameToTypePtr.put(_key21, _val22);
                 }
                 iprot.readMapEnd();
               }
@@ -431,13 +435,13 @@ public class TUnionTypeEntry implements org.apache.thrift.TBase<TUnionTypeEntry,
       {
         org.apache.thrift.protocol.TMap _map26 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
         struct.nameToTypePtr = new HashMap<String,Integer>(2*_map26.size);
-        for (int _i27 = 0; _i27 < _map26.size; ++_i27)
+        String _key27;
+        int _val28;
+        for (int _i29 = 0; _i29 < _map26.size; ++_i29)
         {
-          String _key28; // required
-          int _val29; // required
-          _key28 = iprot.readString();
-          _val29 = iprot.readI32();
-          struct.nameToTypePtr.put(_key28, _val29);
+          _key27 = iprot.readString();
+          _val28 = iprot.readI32();
+          struct.nameToTypePtr.put(_key27, _val28);
         }
       }
       struct.setNameToTypePtrIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUserDefinedTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUserDefinedTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUserDefinedTypeEntry.java
index 3a111a2..107962e 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUserDefinedTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TUserDefinedTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TUserDefinedTypeEntry implements org.apache.thrift.TBase<TUserDefinedTypeEntry, TUserDefinedTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TUserDefinedTypeEntry implements org.apache.thrift.TBase<TUserDefinedTypeEntry, TUserDefinedTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TUserDefinedTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TUserDefinedTypeEntry");
 
   private static final org.apache.thrift.protocol.TField TYPE_CLASS_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("typeClassName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class TUserDefinedTypeEntry implements org.apache.thrift.TBase<TUserDefin
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_typeClassName = true && (isSetTypeClassName());
-    builder.append(present_typeClassName);
+    list.add(present_typeClassName);
     if (present_typeClassName)
-      builder.append(typeClassName);
+      list.add(typeClassName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TUserDefinedTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TUserDefinedTypeEntry typedOther = (TUserDefinedTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetTypeClassName()).compareTo(typedOther.isSetTypeClassName());
+    lastComparison = Boolean.valueOf(isSetTypeClassName()).compareTo(other.isSetTypeClassName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTypeClassName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeClassName, typedOther.typeClassName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeClassName, other.typeClassName);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-php/TCLIService.php
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-php/TCLIService.php b/service/src/gen/thrift/gen-php/TCLIService.php
index d246296..f5dd904 100644
--- a/service/src/gen/thrift/gen-php/TCLIService.php
+++ b/service/src/gen/thrift/gen-php/TCLIService.php
@@ -1,7 +1,7 @@
 <?php
 namespace ;
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,28 +12,105 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
 interface TCLIServiceIf {
+  /**
+   * @param \TOpenSessionReq $req
+   * @return \TOpenSessionResp
+   */
   public function OpenSession(\TOpenSessionReq $req);
+  /**
+   * @param \TCloseSessionReq $req
+   * @return \TCloseSessionResp
+   */
   public function CloseSession(\TCloseSessionReq $req);
+  /**
+   * @param \TGetInfoReq $req
+   * @return \TGetInfoResp
+   */
   public function GetInfo(\TGetInfoReq $req);
+  /**
+   * @param \TExecuteStatementReq $req
+   * @return \TExecuteStatementResp
+   */
   public function ExecuteStatement(\TExecuteStatementReq $req);
+  /**
+   * @param \TGetTypeInfoReq $req
+   * @return \TGetTypeInfoResp
+   */
   public function GetTypeInfo(\TGetTypeInfoReq $req);
+  /**
+   * @param \TGetCatalogsReq $req
+   * @return \TGetCatalogsResp
+   */
   public function GetCatalogs(\TGetCatalogsReq $req);
+  /**
+   * @param \TGetSchemasReq $req
+   * @return \TGetSchemasResp
+   */
   public function GetSchemas(\TGetSchemasReq $req);
+  /**
+   * @param \TGetTablesReq $req
+   * @return \TGetTablesResp
+   */
   public function GetTables(\TGetTablesReq $req);
+  /**
+   * @param \TGetTableTypesReq $req
+   * @return \TGetTableTypesResp
+   */
   public function GetTableTypes(\TGetTableTypesReq $req);
+  /**
+   * @param \TGetColumnsReq $req
+   * @return \TGetColumnsResp
+   */
   public function GetColumns(\TGetColumnsReq $req);
+  /**
+   * @param \TGetFunctionsReq $req
+   * @return \TGetFunctionsResp
+   */
   public function GetFunctions(\TGetFunctionsReq $req);
+  /**
+   * @param \TGetOperationStatusReq $req
+   * @return \TGetOperationStatusResp
+   */
   public function GetOperationStatus(\TGetOperationStatusReq $req);
+  /**
+   * @param \TCancelOperationReq $req
+   * @return \TCancelOperationResp
+   */
   public function CancelOperation(\TCancelOperationReq $req);
+  /**
+   * @param \TCloseOperationReq $req
+   * @return \TCloseOperationResp
+   */
   public function CloseOperation(\TCloseOperationReq $req);
+  /**
+   * @param \TGetResultSetMetadataReq $req
+   * @return \TGetResultSetMetadataResp
+   */
   public function GetResultSetMetadata(\TGetResultSetMetadataReq $req);
+  /**
+   * @param \TFetchResultsReq $req
+   * @return \TFetchResultsResp
+   */
   public function FetchResults(\TFetchResultsReq $req);
+  /**
+   * @param \TGetDelegationTokenReq $req
+   * @return \TGetDelegationTokenResp
+   */
   public function GetDelegationToken(\TGetDelegationTokenReq $req);
+  /**
+   * @param \TCancelDelegationTokenReq $req
+   * @return \TCancelDelegationTokenResp
+   */
   public function CancelDelegationToken(\TCancelDelegationTokenReq $req);
+  /**
+   * @param \TRenewDelegationTokenReq $req
+   * @return \TRenewDelegationTokenResp
+   */
   public function RenewDelegationToken(\TRenewDelegationTokenReq $req);
 }
 
@@ -58,7 +135,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_OpenSession_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'OpenSession', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -74,7 +151,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_OpenSession()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_OpenSession_result', $this->input_->isStrictRead());
     else
     {
@@ -109,7 +186,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_CloseSession_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'CloseSession', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -125,7 +202,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_CloseSession()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_CloseSession_result', $this->input_->isStrictRead());
     else
     {
@@ -160,7 +237,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetInfo_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetInfo', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -176,7 +253,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetInfo()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetInfo_result', $this->input_->isStrictRead());
     else
     {
@@ -211,7 +288,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_ExecuteStatement_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'ExecuteStatement', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -227,7 +304,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_ExecuteStatement()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_ExecuteStatement_result', $this->input_->isStrictRead());
     else
     {
@@ -262,7 +339,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetTypeInfo_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetTypeInfo', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -278,7 +355,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetTypeInfo()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetTypeInfo_result', $this->input_->isStrictRead());
     else
     {
@@ -313,7 +390,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetCatalogs_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetCatalogs', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -329,7 +406,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetCatalogs()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetCatalogs_result', $this->input_->isStrictRead());
     else
     {
@@ -364,7 +441,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetSchemas_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetSchemas', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -380,7 +457,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetSchemas()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetSchemas_result', $this->input_->isStrictRead());
     else
     {
@@ -415,7 +492,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetTables_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetTables', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -431,7 +508,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetTables()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetTables_result', $this->input_->isStrictRead());
     else
     {
@@ -466,7 +543,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetTableTypes_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetTableTypes', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -482,7 +559,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetTableTypes()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetTableTypes_result', $this->input_->isStrictRead());
     else
     {
@@ -517,7 +594,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetColumns_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetColumns', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -533,7 +610,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetColumns()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetColumns_result', $this->input_->isStrictRead());
     else
     {
@@ -568,7 +645,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetFunctions_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetFunctions', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -584,7 +661,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetFunctions()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetFunctions_result', $this->input_->isStrictRead());
     else
     {
@@ -619,7 +696,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetOperationStatus_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetOperationStatus', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -635,7 +712,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetOperationStatus()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetOperationStatus_result', $this->input_->isStrictRead());
     else
     {
@@ -670,7 +747,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_CancelOperation_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'CancelOperation', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -686,7 +763,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_CancelOperation()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_CancelOperation_result', $this->input_->isStrictRead());
     else
     {
@@ -721,7 +798,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_CloseOperation_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'CloseOperation', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -737,7 +814,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_CloseOperation()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_CloseOperation_result', $this->input_->isStrictRead());
     else
     {
@@ -772,7 +849,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetResultSetMetadata_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetResultSetMetadata', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -788,7 +865,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetResultSetMetadata()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetResultSetMetadata_result', $this->input_->isStrictRead());
     else
     {
@@ -823,7 +900,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_FetchResults_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'FetchResults', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -839,7 +916,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_FetchResults()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_FetchResults_result', $this->input_->isStrictRead());
     else
     {
@@ -874,7 +951,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_GetDelegationToken_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'GetDelegationToken', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -890,7 +967,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_GetDelegationToken()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_GetDelegationToken_result', $this->input_->isStrictRead());
     else
     {
@@ -925,7 +1002,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_CancelDelegationToken_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'CancelDelegationToken', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -941,7 +1018,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_CancelDelegationToken()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_CancelDelegationToken_result', $this->input_->isStrictRead());
     else
     {
@@ -976,7 +1053,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
   {
     $args = new \TCLIService_RenewDelegationToken_args();
     $args->req = $req;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'RenewDelegationToken', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -992,7 +1069,7 @@ class TCLIServiceClient implements \TCLIServiceIf {
 
   public function recv_RenewDelegationToken()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\TCLIService_RenewDelegationToken_result', $this->input_->isStrictRead());
     else
     {
@@ -1024,6 +1101,9 @@ class TCLIServiceClient implements \TCLIServiceIf {
 class TCLIService_OpenSession_args {
   static $_TSPEC;
 
+  /**
+   * @var \TOpenSessionReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1101,6 +1181,9 @@ class TCLIService_OpenSession_args {
 class TCLIService_OpenSession_result {
   static $_TSPEC;
 
+  /**
+   * @var \TOpenSessionResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1178,6 +1261,9 @@ class TCLIService_OpenSession_result {
 class TCLIService_CloseSession_args {
   static $_TSPEC;
 
+  /**
+   * @var \TCloseSessionReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1255,6 +1341,9 @@ class TCLIService_CloseSession_args {
 class TCLIService_CloseSession_result {
   static $_TSPEC;
 
+  /**
+   * @var \TCloseSessionResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1332,6 +1421,9 @@ class TCLIService_CloseSession_result {
 class TCLIService_GetInfo_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetInfoReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1409,6 +1501,9 @@ class TCLIService_GetInfo_args {
 class TCLIService_GetInfo_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetInfoResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1486,6 +1581,9 @@ class TCLIService_GetInfo_result {
 class TCLIService_ExecuteStatement_args {
   static $_TSPEC;
 
+  /**
+   * @var \TExecuteStatementReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1563,6 +1661,9 @@ class TCLIService_ExecuteStatement_args {
 class TCLIService_ExecuteStatement_result {
   static $_TSPEC;
 
+  /**
+   * @var \TExecuteStatementResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1640,6 +1741,9 @@ class TCLIService_ExecuteStatement_result {
 class TCLIService_GetTypeInfo_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTypeInfoReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1717,6 +1821,9 @@ class TCLIService_GetTypeInfo_args {
 class TCLIService_GetTypeInfo_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTypeInfoResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1794,6 +1901,9 @@ class TCLIService_GetTypeInfo_result {
 class TCLIService_GetCatalogs_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetCatalogsReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -1871,6 +1981,9 @@ class TCLIService_GetCatalogs_args {
 class TCLIService_GetCatalogs_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetCatalogsResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1948,6 +2061,9 @@ class TCLIService_GetCatalogs_result {
 class TCLIService_GetSchemas_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetSchemasReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2025,6 +2141,9 @@ class TCLIService_GetSchemas_args {
 class TCLIService_GetSchemas_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetSchemasResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2102,6 +2221,9 @@ class TCLIService_GetSchemas_result {
 class TCLIService_GetTables_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTablesReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2179,6 +2301,9 @@ class TCLIService_GetTables_args {
 class TCLIService_GetTables_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTablesResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2256,6 +2381,9 @@ class TCLIService_GetTables_result {
 class TCLIService_GetTableTypes_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTableTypesReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2333,6 +2461,9 @@ class TCLIService_GetTableTypes_args {
 class TCLIService_GetTableTypes_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetTableTypesResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2410,6 +2541,9 @@ class TCLIService_GetTableTypes_result {
 class TCLIService_GetColumns_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetColumnsReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2487,6 +2621,9 @@ class TCLIService_GetColumns_args {
 class TCLIService_GetColumns_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetColumnsResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2564,6 +2701,9 @@ class TCLIService_GetColumns_result {
 class TCLIService_GetFunctions_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetFunctionsReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2641,6 +2781,9 @@ class TCLIService_GetFunctions_args {
 class TCLIService_GetFunctions_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetFunctionsResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2718,6 +2861,9 @@ class TCLIService_GetFunctions_result {
 class TCLIService_GetOperationStatus_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetOperationStatusReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2795,6 +2941,9 @@ class TCLIService_GetOperationStatus_args {
 class TCLIService_GetOperationStatus_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetOperationStatusResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2872,6 +3021,9 @@ class TCLIService_GetOperationStatus_result {
 class TCLIService_CancelOperation_args {
   static $_TSPEC;
 
+  /**
+   * @var \TCancelOperationReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -2949,6 +3101,9 @@ class TCLIService_CancelOperation_args {
 class TCLIService_CancelOperation_result {
   static $_TSPEC;
 
+  /**
+   * @var \TCancelOperationResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3026,6 +3181,9 @@ class TCLIService_CancelOperation_result {
 class TCLIService_CloseOperation_args {
   static $_TSPEC;
 
+  /**
+   * @var \TCloseOperationReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3103,6 +3261,9 @@ class TCLIService_CloseOperation_args {
 class TCLIService_CloseOperation_result {
   static $_TSPEC;
 
+  /**
+   * @var \TCloseOperationResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3180,6 +3341,9 @@ class TCLIService_CloseOperation_result {
 class TCLIService_GetResultSetMetadata_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetResultSetMetadataReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3257,6 +3421,9 @@ class TCLIService_GetResultSetMetadata_args {
 class TCLIService_GetResultSetMetadata_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetResultSetMetadataResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3334,6 +3501,9 @@ class TCLIService_GetResultSetMetadata_result {
 class TCLIService_FetchResults_args {
   static $_TSPEC;
 
+  /**
+   * @var \TFetchResultsReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3411,6 +3581,9 @@ class TCLIService_FetchResults_args {
 class TCLIService_FetchResults_result {
   static $_TSPEC;
 
+  /**
+   * @var \TFetchResultsResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3488,6 +3661,9 @@ class TCLIService_FetchResults_result {
 class TCLIService_GetDelegationToken_args {
   static $_TSPEC;
 
+  /**
+   * @var \TGetDelegationTokenReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3565,6 +3741,9 @@ class TCLIService_GetDelegationToken_args {
 class TCLIService_GetDelegationToken_result {
   static $_TSPEC;
 
+  /**
+   * @var \TGetDelegationTokenResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3642,6 +3821,9 @@ class TCLIService_GetDelegationToken_result {
 class TCLIService_CancelDelegationToken_args {
   static $_TSPEC;
 
+  /**
+   * @var \TCancelDelegationTokenReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3719,6 +3901,9 @@ class TCLIService_CancelDelegationToken_args {
 class TCLIService_CancelDelegationToken_result {
   static $_TSPEC;
 
+  /**
+   * @var \TCancelDelegationTokenResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -3796,6 +3981,9 @@ class TCLIService_CancelDelegationToken_result {
 class TCLIService_RenewDelegationToken_args {
   static $_TSPEC;
 
+  /**
+   * @var \TRenewDelegationTokenReq
+   */
   public $req = null;
 
   public function __construct($vals=null) {
@@ -3873,6 +4061,9 @@ class TCLIService_RenewDelegationToken_args {
 class TCLIService_RenewDelegationToken_result {
   static $_TSPEC;
 
+  /**
+   * @var \TRenewDelegationTokenResp
+   */
   public $success = null;
 
   public function __construct($vals=null) {


[24/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-rb/queryplan_constants.rb
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-rb/queryplan_constants.rb b/ql/src/gen/thrift/gen-rb/queryplan_constants.rb
index 8080b3f..428185e 100644
--- a/ql/src/gen/thrift/gen-rb/queryplan_constants.rb
+++ b/ql/src/gen/thrift/gen-rb/queryplan_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-rb/queryplan_types.rb
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-rb/queryplan_types.rb b/ql/src/gen/thrift/gen-rb/queryplan_types.rb
index c2c4220..1a22f07 100644
--- a/ql/src/gen/thrift/gen-rb/queryplan_types.rb
+++ b/ql/src/gen/thrift/gen-rb/queryplan_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -46,8 +46,9 @@ module OperatorType
   ORCFILEMERGE = 22
   RCFILEMERGE = 23
   MERGEJOIN = 24
-  VALUE_MAP = {0 => "JOIN", 1 => "MAPJOIN", 2 => "EXTRACT", 3 => "FILTER", 4 => "FORWARD", 5 => "GROUPBY", 6 => "LIMIT", 7 => "SCRIPT", 8 => "SELECT", 9 => "TABLESCAN", 10 => "FILESINK", 11 => "REDUCESINK", 12 => "UNION", 13 => "UDTF", 14 => "LATERALVIEWJOIN", 15 => "LATERALVIEWFORWARD", 16 => "HASHTABLESINK", 17 => "HASHTABLEDUMMY", 18 => "PTF", 19 => "MUX", 20 => "DEMUX", 21 => "EVENT", 22 => "ORCFILEMERGE", 23 => "RCFILEMERGE", 24 => "MERGEJOIN"}
-  VALID_VALUES = Set.new([JOIN, MAPJOIN, EXTRACT, FILTER, FORWARD, GROUPBY, LIMIT, SCRIPT, SELECT, TABLESCAN, FILESINK, REDUCESINK, UNION, UDTF, LATERALVIEWJOIN, LATERALVIEWFORWARD, HASHTABLESINK, HASHTABLEDUMMY, PTF, MUX, DEMUX, EVENT, ORCFILEMERGE, RCFILEMERGE, MERGEJOIN]).freeze
+  SPARKPRUNINGSINK = 25
+  VALUE_MAP = {0 => "JOIN", 1 => "MAPJOIN", 2 => "EXTRACT", 3 => "FILTER", 4 => "FORWARD", 5 => "GROUPBY", 6 => "LIMIT", 7 => "SCRIPT", 8 => "SELECT", 9 => "TABLESCAN", 10 => "FILESINK", 11 => "REDUCESINK", 12 => "UNION", 13 => "UDTF", 14 => "LATERALVIEWJOIN", 15 => "LATERALVIEWFORWARD", 16 => "HASHTABLESINK", 17 => "HASHTABLEDUMMY", 18 => "PTF", 19 => "MUX", 20 => "DEMUX", 21 => "EVENT", 22 => "ORCFILEMERGE", 23 => "RCFILEMERGE", 24 => "MERGEJOIN", 25 => "SPARKPRUNINGSINK"}
+  VALID_VALUES = Set.new([JOIN, MAPJOIN, EXTRACT, FILTER, FORWARD, GROUPBY, LIMIT, SCRIPT, SELECT, TABLESCAN, FILESINK, REDUCESINK, UNION, UDTF, LATERALVIEWJOIN, LATERALVIEWFORWARD, HASHTABLESINK, HASHTABLEDUMMY, PTF, MUX, DEMUX, EVENT, ORCFILEMERGE, RCFILEMERGE, MERGEJOIN, SPARKPRUNINGSINK]).freeze
 end
 
 module TaskType

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/exec/OperatorFactory.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/exec/OperatorFactory.java b/ql/src/java/org/apache/hadoop/hive/ql/exec/OperatorFactory.java
index f58a10b..ff58741 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/exec/OperatorFactory.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/exec/OperatorFactory.java
@@ -34,8 +34,11 @@ import org.apache.hadoop.hive.ql.exec.vector.VectorReduceSinkOperator;
 import org.apache.hadoop.hive.ql.exec.vector.VectorSMBMapJoinOperator;
 import org.apache.hadoop.hive.ql.exec.vector.VectorSelectOperator;
 import org.apache.hadoop.hive.ql.exec.vector.VectorSparkHashTableSinkOperator;
+import org.apache.hadoop.hive.ql.exec.vector.VectorSparkPartitionPruningSinkOperator;
 import org.apache.hadoop.hive.ql.exec.vector.VectorizationContext;
 import org.apache.hadoop.hive.ql.metadata.HiveException;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
+import org.apache.hadoop.hive.ql.parse.spark.SparkPartitionPruningSinkOperator;
 import org.apache.hadoop.hive.ql.plan.AppMasterEventDesc;
 import org.apache.hadoop.hive.ql.plan.CollectDesc;
 import org.apache.hadoop.hive.ql.plan.CommonMergeJoinDesc;
@@ -117,6 +120,8 @@ public final class OperatorFactory {
         AppMasterEventOperator.class));
     opvec.add(new OpTuple<DynamicPruningEventDesc>(DynamicPruningEventDesc.class,
         AppMasterEventOperator.class));
+    opvec.add(new OpTuple<SparkPartitionPruningSinkDesc>(SparkPartitionPruningSinkDesc.class,
+        SparkPartitionPruningSinkOperator.class));
     opvec.add(new OpTuple<RCFileMergeDesc>(RCFileMergeDesc.class,
         RCFileMergeOperator.class));
     opvec.add(new OpTuple<OrcFileMergeDesc>(OrcFileMergeDesc.class,
@@ -133,6 +138,9 @@ public final class OperatorFactory {
         VectorAppMasterEventOperator.class));
     vectorOpvec.add(new OpTuple<DynamicPruningEventDesc>(DynamicPruningEventDesc.class,
         VectorAppMasterEventOperator.class));
+    vectorOpvec.add(new OpTuple<SparkPartitionPruningSinkDesc>(
+        SparkPartitionPruningSinkDesc.class,
+        VectorSparkPartitionPruningSinkOperator.class));
     vectorOpvec.add(new OpTuple<SelectDesc>(SelectDesc.class, VectorSelectOperator.class));
     vectorOpvec.add(new OpTuple<GroupByDesc>(GroupByDesc.class, VectorGroupByOperator.class));
     vectorOpvec.add(new OpTuple<MapJoinDesc>(MapJoinDesc.class, VectorMapJoinOperator.class));

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/HiveSparkClientFactory.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/HiveSparkClientFactory.java b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/HiveSparkClientFactory.java
index 21398d8..007db75 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/HiveSparkClientFactory.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/HiveSparkClientFactory.java
@@ -33,6 +33,7 @@ import org.apache.hadoop.hive.conf.HiveConf;
 import org.apache.hadoop.hive.ql.exec.vector.VectorizedRowBatch;
 import org.apache.hadoop.hive.ql.io.HiveKey;
 import org.apache.hadoop.io.BytesWritable;
+import org.apache.hadoop.io.Writable;
 import org.apache.hive.spark.client.rpc.RpcConfiguration;
 import org.apache.spark.SparkConf;
 import org.apache.spark.SparkException;
@@ -148,11 +149,11 @@ public class HiveSparkClientFactory {
     Set<String> classes = Sets.newHashSet(
       Splitter.on(",").trimResults().omitEmptyStrings().split(
         Strings.nullToEmpty(sparkConf.get("spark.kryo.classesToRegister"))));
+    classes.add(Writable.class.getName());
     classes.add(VectorizedRowBatch.class.getName());
     classes.add(BytesWritable.class.getName());
     classes.add(HiveKey.class.getName());
-    sparkConf.put(
-      "spark.kryo.classesToRegister", Joiner.on(",").join(classes));
+    sparkConf.put("spark.kryo.classesToRegister", Joiner.on(",").join(classes));
 
     return sparkConf;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkDynamicPartitionPruner.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkDynamicPartitionPruner.java b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkDynamicPartitionPruner.java
new file mode 100644
index 0000000..52913e0
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkDynamicPartitionPruner.java
@@ -0,0 +1,268 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.exec.spark;
+
+import java.io.IOException;
+import java.io.ObjectInputStream;
+import java.util.ArrayList;
+import java.util.Collections;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Iterator;
+import java.util.LinkedHashMap;
+import java.util.List;
+import java.util.Map;
+import java.util.Set;
+
+import com.clearspring.analytics.util.Preconditions;
+import javolution.testing.AssertionException;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.hadoop.fs.FileStatus;
+import org.apache.hadoop.fs.FileSystem;
+import org.apache.hadoop.fs.Path;
+import org.apache.hadoop.hive.ql.exec.ExprNodeEvaluator;
+import org.apache.hadoop.hive.ql.exec.ExprNodeEvaluatorFactory;
+import org.apache.hadoop.hive.ql.metadata.HiveException;
+import org.apache.hadoop.hive.ql.plan.ExprNodeDesc;
+import org.apache.hadoop.hive.ql.plan.MapWork;
+import org.apache.hadoop.hive.ql.plan.PartitionDesc;
+import org.apache.hadoop.hive.ql.plan.TableDesc;
+import org.apache.hadoop.hive.serde2.Deserializer;
+import org.apache.hadoop.hive.serde2.SerDeException;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorConverters;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorFactory;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspectorUtils;
+import org.apache.hadoop.hive.serde2.objectinspector.StructField;
+import org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector;
+import org.apache.hadoop.hive.serde2.objectinspector.primitive.PrimitiveObjectInspectorFactory;
+import org.apache.hadoop.hive.serde2.typeinfo.TypeInfoFactory;
+import org.apache.hadoop.io.BytesWritable;
+import org.apache.hadoop.mapred.JobConf;
+import org.apache.hadoop.util.ReflectionUtils;
+
+/**
+ * The spark version of DynamicPartitionPruner.
+ */
+public class SparkDynamicPartitionPruner {
+  private static final Log LOG = LogFactory.getLog(SparkDynamicPartitionPruner.class);
+  private final Map<String, List<SourceInfo>> sourceInfoMap = new LinkedHashMap<String, List<SourceInfo>>();
+  private final BytesWritable writable = new BytesWritable();
+
+  public void prune(MapWork work, JobConf jobConf) throws HiveException, SerDeException {
+    sourceInfoMap.clear();
+    initialize(work, jobConf);
+    if (sourceInfoMap.size() == 0) {
+      // Nothing to prune for this MapWork
+      return;
+    }
+    processFiles(work, jobConf);
+    prunePartitions(work);
+  }
+
+  public void initialize(MapWork work, JobConf jobConf) throws SerDeException {
+    Map<String, SourceInfo> columnMap = new HashMap<String, SourceInfo>();
+    Set<String> sourceWorkIds = work.getEventSourceTableDescMap().keySet();
+
+    for (String id : sourceWorkIds) {
+      List<TableDesc> tables = work.getEventSourceTableDescMap().get(id);
+      List<String> columnNames = work.getEventSourceColumnNameMap().get(id);
+      List<ExprNodeDesc> partKeyExprs = work.getEventSourcePartKeyExprMap().get(id);
+
+      Iterator<String> cit = columnNames.iterator();
+      Iterator<ExprNodeDesc> pit = partKeyExprs.iterator();
+      for (TableDesc t : tables) {
+        String columnName = cit.next();
+        ExprNodeDesc partKeyExpr = pit.next();
+        SourceInfo si = new SourceInfo(t, partKeyExpr, columnName, jobConf);
+        if (!sourceInfoMap.containsKey(id)) {
+          sourceInfoMap.put(id, new ArrayList<SourceInfo>());
+        }
+        sourceInfoMap.get(id).add(si);
+
+        // We could have multiple sources restrict the same column, need to take
+        // the union of the values in that case.
+        if (columnMap.containsKey(columnName)) {
+          si.values = columnMap.get(columnName).values;
+        }
+        columnMap.put(columnName, si);
+      }
+    }
+  }
+
+  private void processFiles(MapWork work, JobConf jobConf) throws HiveException {
+    ObjectInputStream in = null;
+    try {
+      Path baseDir = work.getTmpPathForPartitionPruning();
+      FileSystem fs = FileSystem.get(baseDir.toUri(), jobConf);
+
+      // Find the SourceInfo to put values in.
+      for (String name : sourceInfoMap.keySet()) {
+        Path sourceDir = new Path(baseDir, name);
+        for (FileStatus fstatus : fs.listStatus(sourceDir)) {
+          LOG.info("Start processing pruning file: " + fstatus.getPath());
+          in = new ObjectInputStream(fs.open(fstatus.getPath()));
+          String columnName = in.readUTF();
+          SourceInfo info = null;
+
+          for (SourceInfo si : sourceInfoMap.get(name)) {
+            if (columnName.equals(si.columnName)) {
+              info = si;
+              break;
+            }
+          }
+
+          Preconditions.checkArgument(info != null,
+              "AssertionError: no source info for the column: " + columnName);
+
+          // Read fields
+          while (in.available() > 0) {
+            writable.readFields(in);
+
+            Object row = info.deserializer.deserialize(writable);
+            Object value = info.soi.getStructFieldData(row, info.field);
+            value = ObjectInspectorUtils.copyToStandardObject(value, info.fieldInspector);
+            info.values.add(value);
+          }
+        }
+      }
+    } catch (Exception e) {
+      throw new HiveException(e);
+    } finally {
+      try {
+        if (in != null) {
+          in.close();
+        }
+      } catch (IOException e) {
+        throw new HiveException("error while trying to close input stream", e);
+      }
+    }
+  }
+
+  private void prunePartitions(MapWork work) throws HiveException {
+    for (String source : sourceInfoMap.keySet()) {
+      for (SourceInfo info : sourceInfoMap.get(source)) {
+        prunePartitionSingleSource(info, work);
+      }
+    }
+  }
+
+  private void prunePartitionSingleSource(SourceInfo info, MapWork work)
+      throws HiveException {
+    Set<Object> values = info.values;
+    String columnName = info.columnName;
+
+    ObjectInspector oi =
+        PrimitiveObjectInspectorFactory.getPrimitiveWritableObjectInspector(TypeInfoFactory
+            .getPrimitiveTypeInfo(info.fieldInspector.getTypeName()));
+
+    ObjectInspectorConverters.Converter converter =
+        ObjectInspectorConverters.getConverter(
+            PrimitiveObjectInspectorFactory.javaStringObjectInspector, oi);
+
+    StructObjectInspector soi =
+        ObjectInspectorFactory.getStandardStructObjectInspector(
+            Collections.singletonList(columnName), Collections.singletonList(oi));
+
+    @SuppressWarnings("rawtypes")
+    ExprNodeEvaluator eval = ExprNodeEvaluatorFactory.get(info.partKey);
+    eval.initialize(soi);
+
+    applyFilterToPartitions(work, converter, eval, columnName, values);
+  }
+
+  private void applyFilterToPartitions(
+      MapWork work,
+      ObjectInspectorConverters.Converter converter,
+      ExprNodeEvaluator eval,
+      String columnName,
+      Set<Object> values) throws HiveException {
+
+    Object[] row = new Object[1];
+
+    Iterator<String> it = work.getPathToPartitionInfo().keySet().iterator();
+    while (it.hasNext()) {
+      String p = it.next();
+      PartitionDesc desc = work.getPathToPartitionInfo().get(p);
+      Map<String, String> spec = desc.getPartSpec();
+      if (spec == null) {
+        throw new AssertionException("No partition spec found in dynamic pruning");
+      }
+
+      String partValueString = spec.get(columnName);
+      if (partValueString == null) {
+        throw new AssertionException("Could not find partition value for column: " + columnName);
+      }
+
+      Object partValue = converter.convert(partValueString);
+      if (LOG.isDebugEnabled()) {
+        LOG.debug("Converted partition value: " + partValue + " original (" + partValueString + ")");
+      }
+
+      row[0] = partValue;
+      partValue = eval.evaluate(row);
+      if (LOG.isDebugEnabled()) {
+        LOG.debug("part key expr applied: " + partValue);
+      }
+
+      if (!values.contains(partValue)) {
+        LOG.info("Pruning path: " + p);
+        it.remove();
+        work.getPathToAliases().remove(p);
+        work.getPaths().remove(p);
+        work.getPartitionDescs().remove(desc);
+      }
+    }
+  }
+
+  @SuppressWarnings("deprecation")
+  private static class SourceInfo {
+    final ExprNodeDesc partKey;
+    final Deserializer deserializer;
+    final StructObjectInspector soi;
+    final StructField field;
+    final ObjectInspector fieldInspector;
+    Set<Object> values = new HashSet<Object>();
+    final String columnName;
+
+    SourceInfo(TableDesc table, ExprNodeDesc partKey, String columnName, JobConf jobConf)
+        throws SerDeException {
+      this.partKey = partKey;
+      this.columnName = columnName;
+
+      deserializer = ReflectionUtils.newInstance(table.getDeserializerClass(), null);
+      deserializer.initialize(jobConf, table.getProperties());
+
+      ObjectInspector inspector = deserializer.getObjectInspector();
+      if (LOG.isDebugEnabled()) {
+        LOG.debug("Type of obj insp: " + inspector.getTypeName());
+      }
+
+      soi = (StructObjectInspector) inspector;
+      List<? extends StructField> fields = soi.getAllStructFieldRefs();
+      assert(fields.size() > 1) : "expecting single field in input";
+
+      field = fields.get(0);
+      fieldInspector =
+          ObjectInspectorUtils.getStandardObjectInspector(field.getFieldObjectInspector());
+    }
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkUtilities.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkUtilities.java b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkUtilities.java
index ca0ffb6..cf2c3bc 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkUtilities.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/exec/spark/SparkUtilities.java
@@ -23,16 +23,22 @@ import java.net.URI;
 import java.net.URISyntaxException;
 import java.util.Collection;
 import java.util.UUID;
+import java.util.Collection;
 
+import com.google.common.base.Preconditions;
 import org.apache.commons.io.FilenameUtils;
 import org.apache.hadoop.conf.Configuration;
 import org.apache.hadoop.fs.FileSystem;
 import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.hive.conf.HiveConf;
+import org.apache.hadoop.hive.ql.exec.Operator;
+import org.apache.hadoop.hive.ql.exec.TaskFactory;
 import org.apache.hadoop.hive.ql.exec.spark.session.SparkSession;
 import org.apache.hadoop.hive.ql.exec.spark.session.SparkSessionManager;
 import org.apache.hadoop.hive.ql.io.HiveKey;
 import org.apache.hadoop.hive.ql.metadata.HiveException;
+import org.apache.hadoop.hive.ql.plan.BaseWork;
+import org.apache.hadoop.hive.ql.plan.SparkWork;
 import org.apache.hadoop.hive.ql.session.SessionState;
 import org.apache.hadoop.io.BytesWritable;
 import org.apache.spark.Dependency;
@@ -158,4 +164,54 @@ public class SparkUtilities {
       }
     }
   }
+
+  /**
+   * Generate a temporary path for dynamic partition pruning in Spark branch
+   * TODO: no longer need this if we use accumulator!
+   * @param basePath
+   * @param id
+   * @return
+   */
+  public static Path generateTmpPathForPartitionPruning(Path basePath, String id) {
+    return new Path(basePath, id);
+  }
+
+  /**
+   * Return the ID for this BaseWork, in String form.
+   * @param work the input BaseWork
+   * @return the unique ID for this BaseWork
+   */
+  public static String getWorkId(BaseWork work) {
+    String workName = work.getName();
+    return workName.substring(workName.indexOf(" ") + 1);
+  }
+
+  public static SparkTask createSparkTask(HiveConf conf) {
+    return (SparkTask) TaskFactory.get(
+        new SparkWork(conf.getVar(HiveConf.ConfVars.HIVEQUERYID)), conf);
+  }
+
+  public static SparkTask createSparkTask(SparkWork work, HiveConf conf) {
+    return (SparkTask) TaskFactory.get(work, conf);
+  }
+
+  /**
+   * Recursively find all operators under root, that are of class clazz, and
+   * put them in result.
+   * @param result all operators under root that are of class clazz
+   * @param root the root operator under which all operators will be examined
+   * @param clazz clas to collect. Must NOT be null.
+   */
+  public static void collectOp(Collection<Operator<?>> result, Operator<?> root, Class<?> clazz) {
+    Preconditions.checkArgument(clazz != null, "AssertionError: clazz should not be null");
+    if (root == null) {
+      return;
+    }
+    if (clazz.equals(root.getClass())) {
+      result.add(root);
+    }
+    for (Operator<?> child : root.getChildOperators()) {
+      collectOp(result, child, clazz);
+    }
+  }
 }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/exec/vector/VectorSparkPartitionPruningSinkOperator.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/exec/vector/VectorSparkPartitionPruningSinkOperator.java b/ql/src/java/org/apache/hadoop/hive/ql/exec/vector/VectorSparkPartitionPruningSinkOperator.java
new file mode 100644
index 0000000..3bce49d
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/exec/vector/VectorSparkPartitionPruningSinkOperator.java
@@ -0,0 +1,99 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.exec.vector;
+
+import java.util.Collection;
+import java.util.concurrent.Future;
+
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.hive.ql.metadata.HiveException;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
+import org.apache.hadoop.hive.ql.parse.spark.SparkPartitionPruningSinkOperator;
+import org.apache.hadoop.hive.ql.plan.OperatorDesc;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector;
+import org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector;
+import org.apache.hadoop.io.Writable;
+
+/**
+ * Vectorized version for SparkPartitionPruningSinkOperator.
+ * Forked from VectorAppMasterEventOperator.
+ **/
+public class VectorSparkPartitionPruningSinkOperator extends SparkPartitionPruningSinkOperator {
+
+  private static final long serialVersionUID = 1L;
+
+  private VectorizationContext vContext;
+
+  protected transient boolean firstBatch;
+
+  protected transient VectorExtractRowDynBatch vectorExtractRowDynBatch;
+
+  protected transient Object[] singleRow;
+
+  public VectorSparkPartitionPruningSinkOperator(VectorizationContext context,
+      OperatorDesc conf) {
+    super();
+    this.conf = (SparkPartitionPruningSinkDesc) conf;
+    this.vContext = context;
+  }
+
+  public VectorSparkPartitionPruningSinkOperator() {
+  }
+
+  @Override
+  public Collection<Future<?>> initializeOp(Configuration hconf) throws HiveException {
+    inputObjInspectors[0] =
+        VectorizedBatchUtil.convertToStandardStructObjectInspector(
+            (StructObjectInspector) inputObjInspectors[0]);
+    Collection<Future<?>> result = super.initializeOp(hconf);
+    assert result.isEmpty();
+
+    firstBatch = true;
+
+    return result;
+  }
+
+  @Override
+  public void process(Object data, int tag) throws HiveException {
+    VectorizedRowBatch batch = (VectorizedRowBatch) data;
+    if (firstBatch) {
+      vectorExtractRowDynBatch = new VectorExtractRowDynBatch();
+      vectorExtractRowDynBatch.init((StructObjectInspector) inputObjInspectors[0],
+          vContext.getProjectedColumns());
+      singleRow = new Object[vectorExtractRowDynBatch.getCount()];
+      firstBatch = false;
+    }
+
+    vectorExtractRowDynBatch.setBatchOnEntry(batch);
+    ObjectInspector rowInspector = inputObjInspectors[0];
+    try {
+      Writable writableRow;
+      for (int logical = 0; logical < batch.size; logical++) {
+        int batchIndex = batch.selectedInUse ? batch.selected[logical] : logical;
+        vectorExtractRowDynBatch.extractRow(batchIndex, singleRow);
+        writableRow = serializer.serialize(singleRow, rowInspector);
+        writableRow.write(buffer);
+      }
+    } catch (Exception e) {
+      throw new HiveException(e);
+    }
+
+    vectorExtractRowDynBatch.forgetBatchOnExit();
+  }
+}

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/io/CombineHiveInputFormat.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/io/CombineHiveInputFormat.java b/ql/src/java/org/apache/hadoop/hive/ql/io/CombineHiveInputFormat.java
index 1de7e40..e13c4dd 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/io/CombineHiveInputFormat.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/io/CombineHiveInputFormat.java
@@ -25,6 +25,7 @@ import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.HashMap;
 import java.util.HashSet;
+import java.util.Iterator;
 import java.util.LinkedList;
 import java.util.List;
 import java.util.Map;
@@ -514,34 +515,40 @@ public class CombineHiveInputFormat<K extends WritableComparable, V extends Writ
     int numThreads = Math.min(MAX_CHECK_NONCOMBINABLE_THREAD_NUM,
         (int) Math.ceil((double) paths.length / DEFAULT_NUM_PATH_PER_THREAD));
     int numPathPerThread = (int) Math.ceil((double) paths.length / numThreads);
-    LOG.info("Total number of paths: " + paths.length +
-        ", launching " + numThreads + " threads to check non-combinable ones.");
-    ExecutorService executor = Executors.newFixedThreadPool(numThreads);
-    List<Future<Set<Integer>>> futureList = new ArrayList<Future<Set<Integer>>>(numThreads);
-    try {
-      for (int i = 0; i < numThreads; i++) {
-        int start = i * numPathPerThread;
-        int length = i != numThreads - 1 ? numPathPerThread : paths.length - start;
-        futureList.add(executor.submit(
-            new CheckNonCombinablePathCallable(paths, start, length, job)));
-      }
-      Set<Integer> nonCombinablePathIndices = new HashSet<Integer>();
-      for (Future<Set<Integer>> future : futureList) {
-        nonCombinablePathIndices.addAll(future.get());
-      }
-      for (int i = 0; i < paths.length; i++) {
-        if (nonCombinablePathIndices.contains(i)) {
-          nonCombinablePaths.add(paths[i]);
-        } else {
-          combinablePaths.add(paths[i]);
+
+    // This check is necessary because for Spark branch, the result array from
+    // getInputPaths() above could be empty, and therefore numThreads could be 0.
+    // In that case, Executors.newFixedThreadPool will fail.
+    if (numThreads > 0) {
+      LOG.info("Total number of paths: " + paths.length +
+          ", launching " + numThreads + " threads to check non-combinable ones.");
+      ExecutorService executor = Executors.newFixedThreadPool(numThreads);
+      List<Future<Set<Integer>>> futureList = new ArrayList<Future<Set<Integer>>>(numThreads);
+      try {
+        for (int i = 0; i < numThreads; i++) {
+          int start = i * numPathPerThread;
+          int length = i != numThreads - 1 ? numPathPerThread : paths.length - start;
+          futureList.add(executor.submit(
+              new CheckNonCombinablePathCallable(paths, start, length, job)));
+        }
+        Set<Integer> nonCombinablePathIndices = new HashSet<Integer>();
+        for (Future<Set<Integer>> future : futureList) {
+          nonCombinablePathIndices.addAll(future.get());
+        }
+        for (int i = 0; i < paths.length; i++) {
+          if (nonCombinablePathIndices.contains(i)) {
+            nonCombinablePaths.add(paths[i]);
+          } else {
+            combinablePaths.add(paths[i]);
+          }
         }
+      } catch (Exception e) {
+        LOG.error("Error checking non-combinable path", e);
+        perfLogger.PerfLogEnd(CLASS_NAME, PerfLogger.GET_SPLITS);
+        throw new IOException(e);
+      } finally {
+        executor.shutdownNow();
       }
-    } catch (Exception e) {
-      LOG.error("Error checking non-combinable path", e);
-      perfLogger.PerfLogEnd(CLASS_NAME, PerfLogger.GET_SPLITS);
-      throw new IOException(e);
-    } finally {
-      executor.shutdownNow();
     }
 
     // Store the previous value for the path specification

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/io/HiveInputFormat.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/io/HiveInputFormat.java b/ql/src/java/org/apache/hadoop/hive/ql/io/HiveInputFormat.java
index 2ff3951..fd16b35 100755
--- a/ql/src/java/org/apache/hadoop/hive/ql/io/HiveInputFormat.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/io/HiveInputFormat.java
@@ -26,6 +26,7 @@ import java.util.ArrayList;
 import java.util.Iterator;
 import java.util.List;
 import java.util.Map;
+import java.util.Set;
 import java.util.concurrent.ConcurrentHashMap;
 import java.util.Map.Entry;
 
@@ -37,6 +38,7 @@ import org.apache.hadoop.fs.Path;
 import org.apache.hadoop.hive.conf.HiveConf;
 import org.apache.hadoop.hive.io.HiveIOExceptionHandlerUtil;
 import org.apache.hadoop.hive.metastore.api.hive_metastoreConstants;
+import org.apache.hadoop.hive.ql.exec.spark.SparkDynamicPartitionPruner;
 import org.apache.hadoop.hive.ql.plan.TableDesc;
 import org.apache.hadoop.hive.ql.exec.Operator;
 import org.apache.hadoop.hive.ql.exec.TableScanOperator;
@@ -266,6 +268,18 @@ public class HiveInputFormat<K extends WritableComparable, V extends Writable>
       } else {
         mrwork = Utilities.getMapWork(job);
       }
+
+      // Prune partitions
+      if (HiveConf.getVar(job, HiveConf.ConfVars.HIVE_EXECUTION_ENGINE).equals("spark")
+          && HiveConf.getBoolVar(job, HiveConf.ConfVars.SPARK_DYNAMIC_PARTITION_PRUNING)) {
+        SparkDynamicPartitionPruner pruner = new SparkDynamicPartitionPruner();
+        try {
+          pruner.prune(mrwork, job);
+        } catch (Exception e) {
+          throw new RuntimeException(e);
+        }
+      }
+
       pathToPartitionInfo = mrwork.getPathToPartitionInfo();
     }
   }
@@ -309,18 +323,28 @@ public class HiveInputFormat<K extends WritableComparable, V extends Writable>
   }
 
   Path[] getInputPaths(JobConf job) throws IOException {
-    Path[] dirs = FileInputFormat.getInputPaths(job);
-    if (dirs.length == 0) {
-      // on tez we're avoiding to duplicate the file info in FileInputFormat.
-      if (HiveConf.getVar(job, HiveConf.ConfVars.HIVE_EXECUTION_ENGINE).equals("tez")) {
-        try {
-          List<Path> paths = Utilities.getInputPathsTez(job, mrwork);
-          dirs = paths.toArray(new Path[paths.size()]);
-        } catch (Exception e) {
-          throw new IOException("Could not create input files", e);
+    Path[] dirs;
+    if (HiveConf.getVar(job, HiveConf.ConfVars.HIVE_EXECUTION_ENGINE).equals("spark")) {
+      Set<String> pathStrings = mrwork.getPathToPartitionInfo().keySet();
+      dirs = new Path[pathStrings.size()];
+      Iterator<String> it = pathStrings.iterator();
+      for (int i = 0; i < dirs.length; i++) {
+        dirs[i] = new Path(it.next());
+      }
+    } else {
+      dirs = FileInputFormat.getInputPaths(job);
+      if (dirs.length == 0) {
+        // on tez we're avoiding to duplicate the file info in FileInputFormat.
+        if (HiveConf.getVar(job, HiveConf.ConfVars.HIVE_EXECUTION_ENGINE).equals("tez")) {
+          try {
+            List<Path> paths = Utilities.getInputPathsTez(job, mrwork);
+            dirs = paths.toArray(new Path[paths.size()]);
+          } catch (Exception e) {
+            throw new IOException("Could not create input files", e);
+          }
+        } else {
+          throw new IOException("No input paths specified in job");
         }
-      } else {
-        throw new IOException("No input paths specified in job");
       }
     }
     return dirs;

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/optimizer/DynamicPartitionPruningOptimization.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/DynamicPartitionPruningOptimization.java b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/DynamicPartitionPruningOptimization.java
index 8546d21..f475926 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/DynamicPartitionPruningOptimization.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/DynamicPartitionPruningOptimization.java
@@ -48,10 +48,12 @@ import org.apache.hadoop.hive.ql.lib.Rule;
 import org.apache.hadoop.hive.ql.lib.RuleRegExp;
 import org.apache.hadoop.hive.ql.metadata.Partition;
 import org.apache.hadoop.hive.ql.metadata.Table;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
 import org.apache.hadoop.hive.ql.parse.OptimizeTezProcContext;
 import org.apache.hadoop.hive.ql.parse.ParseContext;
 import org.apache.hadoop.hive.ql.parse.PrunedPartitionList;
 import org.apache.hadoop.hive.ql.parse.SemanticException;
+import org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext;
 import org.apache.hadoop.hive.ql.plan.AggregationDesc;
 import org.apache.hadoop.hive.ql.plan.DynamicPruningEventDesc;
 import org.apache.hadoop.hive.ql.plan.ExprNodeColumnDesc;
@@ -152,15 +154,24 @@ public class DynamicPartitionPruningOptimization implements NodeProcessor {
   @Override
   public Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procCtx, Object... nodeOutputs)
       throws SemanticException {
-    OptimizeTezProcContext context = (OptimizeTezProcContext) procCtx;
-    ParseContext parseContext = context.parseContext;
+    ParseContext parseContext;
+    if (procCtx instanceof OptimizeTezProcContext) {
+      parseContext = ((OptimizeTezProcContext) procCtx).parseContext;
+    } else if (procCtx instanceof OptimizeSparkProcContext) {
+      parseContext = ((OptimizeSparkProcContext) procCtx).getParseContext();
+    } else {
+      throw new IllegalArgumentException("expected parseContext to be either " +
+          "OptimizeTezProcContext or OptimizeSparkProcContext, but found " +
+          procCtx.getClass().getName());
+    }
 
     FilterOperator filter = (FilterOperator) nd;
     FilterDesc desc = filter.getConf();
 
     TableScanOperator ts = null;
 
-    if (!parseContext.getConf().getBoolVar(ConfVars.TEZ_DYNAMIC_PARTITION_PRUNING)) {
+    if (!parseContext.getConf().getBoolVar(ConfVars.TEZ_DYNAMIC_PARTITION_PRUNING) &&
+        !parseContext.getConf().getBoolVar(ConfVars.SPARK_DYNAMIC_PARTITION_PRUNING)) {
       // nothing to do when the optimization is off
       return null;
     }
@@ -311,14 +322,25 @@ public class DynamicPartitionPruningOptimization implements NodeProcessor {
     groupByOp.setColumnExprMap(colMap);
 
     // finally add the event broadcast operator
-    DynamicPruningEventDesc eventDesc = new DynamicPruningEventDesc();
-    eventDesc.setTableScan(ts);
-    eventDesc.setTable(PlanUtils.getReduceValueTableDesc(PlanUtils
-        .getFieldSchemasFromColumnList(keyExprs, "key")));
-    eventDesc.setTargetColumnName(column);
-    eventDesc.setPartKey(partKey);
-
-    OperatorFactory.getAndMakeChild(eventDesc, groupByOp);
+    if (HiveConf.getVar(parseContext.getConf(),
+        ConfVars.HIVE_EXECUTION_ENGINE).equals("tez")) {
+      DynamicPruningEventDesc eventDesc = new DynamicPruningEventDesc();
+      eventDesc.setTableScan(ts);
+      eventDesc.setTable(PlanUtils.getReduceValueTableDesc(PlanUtils
+          .getFieldSchemasFromColumnList(keyExprs, "key")));
+      eventDesc.setTargetColumnName(column);
+      eventDesc.setPartKey(partKey);
+      OperatorFactory.getAndMakeChild(eventDesc, groupByOp);
+    } else {
+      // Must be spark branch
+      SparkPartitionPruningSinkDesc desc = new SparkPartitionPruningSinkDesc();
+      desc.setTableScan(ts);
+      desc.setTable(PlanUtils.getReduceValueTableDesc(PlanUtils
+          .getFieldSchemasFromColumnList(keyExprs, "key")));
+      desc.setTargetColumnName(column);
+      desc.setPartKey(partKey);
+      OperatorFactory.getAndMakeChild(desc, groupByOp);
+    }
   }
 
   private Map<Node, Object> walkExprTree(ExprNodeDesc pred, NodeProcessorCtx ctx)

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/optimizer/Optimizer.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/Optimizer.java b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/Optimizer.java
index a7cf8b7..e6db133 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/Optimizer.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/Optimizer.java
@@ -167,7 +167,7 @@ public class Optimizer {
     if(HiveConf.getBoolVar(hiveConf, HiveConf.ConfVars.HIVEOPTIMIZEMETADATAQUERIES)) {
       transformations.add(new StatsOptimizer());
     }
-    if (isSparkExecEngine || (pctx.getContext().getExplain() && !isTezExecEngine)) {
+    if (pctx.getContext().getExplain() && !isTezExecEngine && !isSparkExecEngine) {
       transformations.add(new AnnotateWithStatistics());
       transformations.add(new AnnotateWithOpTraits());
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/optimizer/SparkRemoveDynamicPruningBySize.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/SparkRemoveDynamicPruningBySize.java b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/SparkRemoveDynamicPruningBySize.java
new file mode 100644
index 0000000..3742857
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/SparkRemoveDynamicPruningBySize.java
@@ -0,0 +1,73 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.optimizer;
+
+import java.util.Stack;
+
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.hadoop.hive.conf.HiveConf.ConfVars;
+import org.apache.hadoop.hive.ql.exec.Operator;
+import org.apache.hadoop.hive.ql.lib.Node;
+import org.apache.hadoop.hive.ql.lib.NodeProcessor;
+import org.apache.hadoop.hive.ql.lib.NodeProcessorCtx;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
+import org.apache.hadoop.hive.ql.parse.SemanticException;
+import org.apache.hadoop.hive.ql.parse.spark.OptimizeSparkProcContext;
+import org.apache.hadoop.hive.ql.parse.spark.SparkPartitionPruningSinkOperator;
+
+/**
+ * If we expect the number of keys for dynamic pruning to be too large we
+ * disable it.
+ *
+ * Cloned from RemoveDynamicPruningBySize
+ */
+public class SparkRemoveDynamicPruningBySize implements NodeProcessor {
+
+  static final private Log LOG = LogFactory.getLog(SparkRemoveDynamicPruningBySize.class.getName());
+
+  @Override
+  public Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procContext,
+      Object... nodeOutputs)
+      throws SemanticException {
+
+    OptimizeSparkProcContext context = (OptimizeSparkProcContext) procContext;
+
+    SparkPartitionPruningSinkOperator op = (SparkPartitionPruningSinkOperator) nd;
+    SparkPartitionPruningSinkDesc desc = op.getConf();
+
+    if (desc.getStatistics().getDataSize() > context.getConf()
+        .getLongVar(ConfVars.SPARK_DYNAMIC_PARTITION_PRUNING_MAX_DATA_SIZE)) {
+      Operator<?> child = op;
+      Operator<?> curr = op;
+
+      while (curr.getChildOperators().size() <= 1) {
+        child = curr;
+        curr = curr.getParentOperators().get(0);
+      }
+
+      curr.removeChild(child);
+      // at this point we've found the fork in the op pipeline that has the pruning as a child plan.
+      LOG.info("Disabling dynamic pruning for: "
+          + desc.getTableScan().getName()
+          + ". Expected data size is too big: " + desc.getStatistics().getDataSize());
+    }
+    return false;
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/optimizer/physical/Vectorizer.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/physical/Vectorizer.java b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/physical/Vectorizer.java
index ad47547..180513e 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/physical/Vectorizer.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/physical/Vectorizer.java
@@ -919,6 +919,7 @@ public class Vectorizer implements PhysicalPlanResolver {
       case FILESINK:
       case LIMIT:
       case EVENT:
+      case SPARKPRUNINGSINK:
         ret = true;
         break;
       case HASHTABLESINK:
@@ -965,6 +966,7 @@ public class Vectorizer implements PhysicalPlanResolver {
         break;
       case LIMIT:
       case EVENT:
+      case SPARKPRUNINGSINK:
         ret = true;
         break;
       case HASHTABLESINK:

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/optimizer/spark/SparkPartitionPruningSinkDesc.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/optimizer/spark/SparkPartitionPruningSinkDesc.java b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/spark/SparkPartitionPruningSinkDesc.java
new file mode 100644
index 0000000..cc78227
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/optimizer/spark/SparkPartitionPruningSinkDesc.java
@@ -0,0 +1,100 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.optimizer.spark;
+
+import org.apache.hadoop.fs.Path;
+import org.apache.hadoop.hive.ql.exec.TableScanOperator;
+import org.apache.hadoop.hive.ql.plan.AbstractOperatorDesc;
+import org.apache.hadoop.hive.ql.plan.Explain;
+import org.apache.hadoop.hive.ql.plan.ExprNodeDesc;
+import org.apache.hadoop.hive.ql.plan.TableDesc;
+
+@Explain(displayName = "Spark Partition Pruning Sink Operator")
+public class SparkPartitionPruningSinkDesc extends AbstractOperatorDesc {
+
+  // column in the target table that will be pruned against
+  private String targetColumnName;
+
+  private TableDesc table;
+
+  private transient TableScanOperator tableScan;
+
+  // the partition column we're interested in
+  private ExprNodeDesc partKey;
+
+  private Path path;
+
+  private String targetWork;
+
+  @Explain(displayName = "tmp Path", explainLevels = { Explain.Level.EXTENDED })
+  public Path getPath() {
+    return path;
+  }
+
+  public void setPath(Path path) {
+    this.path = path;
+  }
+
+  @Explain(displayName = "target work")
+  public String getTargetWork() {
+    return this.targetWork;
+  }
+
+  public void setTargetWork(String targetWork) {
+    this.targetWork = targetWork;
+  }
+
+  public TableScanOperator getTableScan() {
+    return tableScan;
+  }
+
+  public void setTableScan(TableScanOperator tableScan) {
+    this.tableScan = tableScan;
+  }
+
+  @Explain(displayName = "target column name")
+  public String getTargetColumnName() {
+    return targetColumnName;
+  }
+
+  public void setTargetColumnName(String targetColumnName) {
+    this.targetColumnName = targetColumnName;
+  }
+
+  public ExprNodeDesc getPartKey() {
+    return partKey;
+  }
+
+  public void setPartKey(ExprNodeDesc partKey) {
+    this.partKey = partKey;
+  }
+
+  public TableDesc getTable() {
+    return table;
+  }
+
+  public void setTable(TableDesc table) {
+    this.table = table;
+  }
+
+  @Explain(displayName = "partition key expr")
+  public String getPartKeyString() {
+    return partKey.getExprString();
+  }
+}

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkProcContext.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkProcContext.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkProcContext.java
index 447f104..0a0c791 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkProcContext.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkProcContext.java
@@ -30,6 +30,7 @@ import org.apache.hadoop.hive.ql.exec.Task;
 import org.apache.hadoop.hive.ql.exec.TaskFactory;
 import org.apache.hadoop.hive.ql.exec.UnionOperator;
 import org.apache.hadoop.hive.ql.exec.spark.SparkTask;
+import org.apache.hadoop.hive.ql.exec.spark.SparkUtilities;
 import org.apache.hadoop.hive.ql.hooks.ReadEntity;
 import org.apache.hadoop.hive.ql.hooks.WriteEntity;
 import org.apache.hadoop.hive.ql.lib.NodeProcessorCtx;
@@ -40,7 +41,6 @@ import org.apache.hadoop.hive.ql.plan.MoveWork;
 import org.apache.hadoop.hive.ql.plan.OperatorDesc;
 import org.apache.hadoop.hive.ql.plan.ReduceWork;
 import org.apache.hadoop.hive.ql.plan.SparkEdgeProperty;
-import org.apache.hadoop.hive.ql.plan.SparkWork;
 
 import java.io.Serializable;
 import java.util.HashMap;
@@ -138,6 +138,13 @@ public class GenSparkProcContext implements NodeProcessorCtx {
   // This is necessary as sometimes semantic analyzer's mapping is different than operator's own alias.
   public final Map<String, Operator<? extends OperatorDesc>> topOps;
 
+  // The set of pruning sinks
+  public final Set<Operator<?>> pruningSinkSet;
+
+  // The set of TableScanOperators for pruning OP trees
+  public final Set<Operator<?>> clonedPruningTableScanSet;
+
+
   @SuppressWarnings("unchecked")
   public GenSparkProcContext(HiveConf conf,
       ParseContext parseContext,
@@ -153,8 +160,7 @@ public class GenSparkProcContext implements NodeProcessorCtx {
     this.inputs = inputs;
     this.outputs = outputs;
     this.topOps = topOps;
-    this.currentTask = (SparkTask) TaskFactory.get(
-        new SparkWork(conf.getVar(HiveConf.ConfVars.HIVEQUERYID)), conf);
+    this.currentTask = SparkUtilities.createSparkTask(conf);
     this.rootTasks.add(currentTask);
     this.leafOpToFollowingWorkInfo =
         new LinkedHashMap<ReduceSinkOperator, ObjectPair<SparkEdgeProperty, ReduceWork>>();
@@ -177,5 +183,7 @@ public class GenSparkProcContext implements NodeProcessorCtx {
     this.clonedReduceSinks = new LinkedHashSet<ReduceSinkOperator>();
     this.fileSinkSet = new LinkedHashSet<FileSinkOperator>();
     this.fileSinkMap = new LinkedHashMap<FileSinkOperator, List<FileSinkOperator>>();
+    this.pruningSinkSet = new LinkedHashSet<Operator<?>>();
+    this.clonedPruningTableScanSet = new LinkedHashSet<Operator<?>>();
   }
 }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkUtils.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkUtils.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkUtils.java
index 7992c88..1c0b79d 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkUtils.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/GenSparkUtils.java
@@ -46,7 +46,9 @@ import org.apache.hadoop.hive.ql.exec.SMBMapJoinOperator;
 import org.apache.hadoop.hive.ql.exec.TableScanOperator;
 import org.apache.hadoop.hive.ql.exec.UnionOperator;
 import org.apache.hadoop.hive.ql.exec.Utilities;
+import org.apache.hadoop.hive.ql.exec.spark.SparkUtilities;
 import org.apache.hadoop.hive.ql.optimizer.GenMapRedUtils;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
 import org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinFactory;
 import org.apache.hadoop.hive.ql.parse.ParseContext;
 import org.apache.hadoop.hive.ql.parse.PrunedPartitionList;
@@ -61,6 +63,7 @@ import org.apache.hadoop.hive.ql.plan.SparkWork;
 
 import com.google.common.base.Preconditions;
 import com.google.common.base.Strings;
+import org.apache.hadoop.hive.ql.plan.TableDesc;
 
 /**
  * GenSparkUtils is a collection of shared helper methods to produce SparkWork
@@ -132,7 +135,7 @@ public class GenSparkUtils {
 
     // remember which parent belongs to which tag
     reduceWork.getTagToInput().put(reduceSink.getConf().getTag(),
-         context.preceedingWork.getName());
+        context.preceedingWork.getName());
 
     // remember the output name of the reduce sink
     reduceSink.getConf().setOutputName(reduceWork.getName());
@@ -218,6 +221,16 @@ public class GenSparkUtils {
       Iterator<Operator<?>> newOpQueueIt = newOpQueue.iterator();
       for (Operator<?> op : opQueue) {
         Operator<?> newOp = newOpQueueIt.next();
+
+        // We need to update rootToWorkMap in case the op is a key, since even
+        // though we clone the op tree, we're still using the same MapWork/ReduceWork.
+        if (context.rootToWorkMap.containsKey(op)) {
+          context.rootToWorkMap.put(newOp, context.rootToWorkMap.get(op));
+        }
+        // Don't remove the old entry - in SparkPartitionPruningSink it still
+        // refers to the old TS, and we need to lookup it later in
+        // processPartitionPruningSink.
+
         if (op instanceof FileSinkOperator) {
           List<FileSinkOperator> fileSinkList = context.fileSinkMap.get(op);
           if (fileSinkList == null) {
@@ -225,6 +238,12 @@ public class GenSparkUtils {
           }
           fileSinkList.add((FileSinkOperator) newOp);
           context.fileSinkMap.put((FileSinkOperator) op, fileSinkList);
+        } else if (op instanceof SparkPartitionPruningSinkOperator) {
+          SparkPartitionPruningSinkOperator oldPruningSink = (SparkPartitionPruningSinkOperator) op;
+          SparkPartitionPruningSinkOperator newPruningSink = (SparkPartitionPruningSinkOperator) newOp;
+          newPruningSink.getConf().setTableScan(oldPruningSink.getConf().getTableScan());
+          context.pruningSinkSet.add(newPruningSink);
+          context.pruningSinkSet.remove(oldPruningSink);
         }
       }
     }
@@ -337,6 +356,67 @@ public class GenSparkUtils {
     }
   }
 
+  /**
+   * Populate partition pruning information from the pruning sink operator to the
+   * target MapWork (the MapWork for the big table side). The information include the source table
+   * name, column name, and partition key expression. It also set up the temporary path used to
+   * communicate between the target MapWork and source BaseWork.
+   *
+   * Here "source" refers to the small table side, while "target" refers to the big
+   * table side.
+   *
+   * @param context the spark context.
+   * @param pruningSink the pruner sink operator being processed.
+   */
+  public void processPartitionPruningSink(GenSparkProcContext context,
+      SparkPartitionPruningSinkOperator pruningSink) {
+    SparkPartitionPruningSinkDesc desc = pruningSink.getConf();
+    TableScanOperator ts = desc.getTableScan();
+    MapWork targetWork = (MapWork) context.rootToWorkMap.get(ts);
+
+    Preconditions.checkArgument(
+        targetWork != null,
+        "No targetWork found for tablescan " + ts);
+
+    String targetId = SparkUtilities.getWorkId(targetWork);
+
+    BaseWork sourceWork = getEnclosingWork(pruningSink, context);
+    String sourceId = SparkUtilities.getWorkId(sourceWork);
+
+    // set up temporary path to communicate between the small/big table
+    Path tmpPath = targetWork.getTmpPathForPartitionPruning();
+    if (tmpPath == null) {
+      Path baseTmpPath = context.parseContext.getContext().getMRTmpPath();
+      tmpPath = SparkUtilities.generateTmpPathForPartitionPruning(baseTmpPath, targetId);
+      targetWork.setTmpPathForPartitionPruning(tmpPath);
+      LOG.info("Setting tmp path between source work and target work:\n" + tmpPath);
+    }
+
+    desc.setPath(new Path(tmpPath, sourceId));
+    desc.setTargetWork(targetWork.getName());
+
+    // store table descriptor in map-targetWork
+    if (!targetWork.getEventSourceTableDescMap().containsKey(sourceId)) {
+      targetWork.getEventSourceTableDescMap().put(sourceId, new LinkedList<TableDesc>());
+    }
+    List<TableDesc> tables = targetWork.getEventSourceTableDescMap().get(sourceId);
+    tables.add(pruningSink.getConf().getTable());
+
+    // store column name in map-targetWork
+    if (!targetWork.getEventSourceColumnNameMap().containsKey(sourceId)) {
+      targetWork.getEventSourceColumnNameMap().put(sourceId, new LinkedList<String>());
+    }
+    List<String> columns = targetWork.getEventSourceColumnNameMap().get(sourceId);
+    columns.add(desc.getTargetColumnName());
+
+    // store partition key expr in map-targetWork
+    if (!targetWork.getEventSourcePartKeyExprMap().containsKey(sourceId)) {
+      targetWork.getEventSourcePartKeyExprMap().put(sourceId, new LinkedList<ExprNodeDesc>());
+    }
+    List<ExprNodeDesc> keys = targetWork.getEventSourcePartKeyExprMap().get(sourceId);
+    keys.add(desc.getPartKey());
+  }
+
   public static SparkEdgeProperty getEdgeProperty(ReduceSinkOperator reduceSink,
       ReduceWork reduceWork) throws SemanticException {
     SparkEdgeProperty edgeProperty = new SparkEdgeProperty(SparkEdgeProperty.SHUFFLE_NONE);
@@ -490,4 +570,33 @@ public class GenSparkUtils {
     }
     return false;
   }
+
+  /**
+   * getEncosingWork finds the BaseWork any given operator belongs to.
+   */
+  public BaseWork getEnclosingWork(Operator<?> op, GenSparkProcContext procCtx) {
+    List<Operator<?>> ops = new ArrayList<Operator<?>>();
+    findRoots(op, ops);
+    for (Operator<?> r : ops) {
+      BaseWork work = procCtx.rootToWorkMap.get(r);
+      if (work != null) {
+        return work;
+      }
+    }
+    return null;
+  }
+
+  /*
+   * findRoots returns all root operators (in ops) that result in operator op
+   */
+  private void findRoots(Operator<?> op, List<Operator<?>> ops) {
+    List<Operator<?>> parents = op.getParentOperators();
+    if (parents == null || parents.isEmpty()) {
+      ops.add(op);
+      return;
+    }
+    for (Operator<?> p : parents) {
+      findRoots(p, ops);
+    }
+  }
 }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/OptimizeSparkProcContext.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/OptimizeSparkProcContext.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/OptimizeSparkProcContext.java
index f7586a4..3b71af1 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/OptimizeSparkProcContext.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/OptimizeSparkProcContext.java
@@ -20,15 +20,12 @@ package org.apache.hadoop.hive.ql.parse.spark;
 
 import org.apache.hadoop.hive.conf.HiveConf;
 import org.apache.hadoop.hive.ql.exec.MapJoinOperator;
-import org.apache.hadoop.hive.ql.exec.Operator;
 import org.apache.hadoop.hive.ql.exec.ReduceSinkOperator;
 import org.apache.hadoop.hive.ql.hooks.ReadEntity;
 import org.apache.hadoop.hive.ql.hooks.WriteEntity;
 import org.apache.hadoop.hive.ql.lib.NodeProcessorCtx;
 import org.apache.hadoop.hive.ql.parse.ParseContext;
-import org.apache.hadoop.hive.ql.plan.OperatorDesc;
 
-import java.util.Deque;
 import java.util.HashMap;
 import java.util.HashSet;
 import java.util.Map;
@@ -49,19 +46,12 @@ public class OptimizeSparkProcContext implements NodeProcessorCtx {
   private final Set<ReduceSinkOperator> visitedReduceSinks = new HashSet<ReduceSinkOperator>();
   private final Map<MapJoinOperator, Long> mjOpSizes = new HashMap<MapJoinOperator, Long>();
 
-  // rootOperators are all the table scan operators in sequence
-  // of traversal
-  private final Deque<Operator<? extends OperatorDesc>> rootOperators;
-
   public OptimizeSparkProcContext(HiveConf conf, ParseContext parseContext,
-    Set<ReadEntity> inputs, Set<WriteEntity> outputs,
-    Deque<Operator<? extends OperatorDesc>> rootOperators) {
-
+    Set<ReadEntity> inputs, Set<WriteEntity> outputs) {
     this.conf = conf;
     this.parseContext = parseContext;
     this.inputs = inputs;
     this.outputs = outputs;
-    this.rootOperators = rootOperators;
   }
 
   public ParseContext getParseContext() {
@@ -84,10 +74,6 @@ public class OptimizeSparkProcContext implements NodeProcessorCtx {
     return visitedReduceSinks;
   }
 
-  public Deque<Operator<? extends OperatorDesc>> getRootOperators() {
-    return rootOperators;
-  }
-
   public Map<MapJoinOperator, Long> getMjOpSizes() {
     return mjOpSizes;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkCompiler.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkCompiler.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkCompiler.java
index 7f2c079..27a1d99 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkCompiler.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkCompiler.java
@@ -19,10 +19,8 @@ package org.apache.hadoop.hive.ql.parse.spark;
 
 import java.io.Serializable;
 import java.util.ArrayList;
-import java.util.Deque;
 import java.util.HashMap;
 import java.util.LinkedHashMap;
-import java.util.LinkedList;
 import java.util.List;
 import java.util.Map;
 import java.util.Set;
@@ -35,6 +33,7 @@ import org.apache.hadoop.hive.ql.Context;
 import org.apache.hadoop.hive.ql.exec.ConditionalTask;
 import org.apache.hadoop.hive.ql.exec.DummyStoreOperator;
 import org.apache.hadoop.hive.ql.exec.FileSinkOperator;
+import org.apache.hadoop.hive.ql.exec.FilterOperator;
 import org.apache.hadoop.hive.ql.exec.JoinOperator;
 import org.apache.hadoop.hive.ql.exec.MapJoinOperator;
 import org.apache.hadoop.hive.ql.exec.Operator;
@@ -44,12 +43,14 @@ import org.apache.hadoop.hive.ql.exec.TableScanOperator;
 import org.apache.hadoop.hive.ql.exec.Task;
 import org.apache.hadoop.hive.ql.exec.UnionOperator;
 import org.apache.hadoop.hive.ql.exec.spark.SparkTask;
+import org.apache.hadoop.hive.ql.exec.spark.SparkUtilities;
 import org.apache.hadoop.hive.ql.hooks.ReadEntity;
 import org.apache.hadoop.hive.ql.hooks.WriteEntity;
 import org.apache.hadoop.hive.ql.lib.CompositeProcessor;
 import org.apache.hadoop.hive.ql.lib.DefaultGraphWalker;
 import org.apache.hadoop.hive.ql.lib.DefaultRuleDispatcher;
 import org.apache.hadoop.hive.ql.lib.Dispatcher;
+import org.apache.hadoop.hive.ql.lib.ForwardWalker;
 import org.apache.hadoop.hive.ql.lib.GraphWalker;
 import org.apache.hadoop.hive.ql.lib.Node;
 import org.apache.hadoop.hive.ql.lib.NodeProcessor;
@@ -58,7 +59,10 @@ import org.apache.hadoop.hive.ql.lib.Rule;
 import org.apache.hadoop.hive.ql.lib.RuleRegExp;
 import org.apache.hadoop.hive.ql.lib.TypeRule;
 import org.apache.hadoop.hive.ql.log.PerfLogger;
-import org.apache.hadoop.hive.ql.metadata.Hive;
+import org.apache.hadoop.hive.ql.optimizer.ConstantPropagate;
+import org.apache.hadoop.hive.ql.optimizer.DynamicPartitionPruningOptimization;
+import org.apache.hadoop.hive.ql.optimizer.SparkRemoveDynamicPruningBySize;
+import org.apache.hadoop.hive.ql.optimizer.metainfo.annotation.AnnotateWithOpTraits;
 import org.apache.hadoop.hive.ql.optimizer.physical.MetadataOnlyOptimizer;
 import org.apache.hadoop.hive.ql.optimizer.physical.NullScanOptimizer;
 import org.apache.hadoop.hive.ql.optimizer.physical.PhysicalContext;
@@ -72,8 +76,8 @@ import org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinHintOptimizer;
 import org.apache.hadoop.hive.ql.optimizer.spark.SparkJoinOptimizer;
 import org.apache.hadoop.hive.ql.optimizer.spark.SparkReduceSinkMapJoinProc;
 import org.apache.hadoop.hive.ql.optimizer.spark.SparkSkewJoinResolver;
-import org.apache.hadoop.hive.ql.optimizer.spark.SparkSortMergeJoinFactory;
 import org.apache.hadoop.hive.ql.optimizer.spark.SplitSparkWorkResolver;
+import org.apache.hadoop.hive.ql.optimizer.stats.annotation.AnnotateWithStatistics;
 import org.apache.hadoop.hive.ql.parse.GlobalLimitCtx;
 import org.apache.hadoop.hive.ql.parse.ParseContext;
 import org.apache.hadoop.hive.ql.parse.SemanticException;
@@ -83,7 +87,6 @@ import org.apache.hadoop.hive.ql.plan.MapWork;
 import org.apache.hadoop.hive.ql.plan.MoveWork;
 import org.apache.hadoop.hive.ql.plan.OperatorDesc;
 import org.apache.hadoop.hive.ql.plan.SparkWork;
-import org.apache.hadoop.hive.ql.session.SessionState.LogHelper;
 
 /**
  * SparkCompiler translates the operator plan into SparkTasks.
@@ -102,22 +105,70 @@ public class SparkCompiler extends TaskCompiler {
   protected void optimizeOperatorPlan(ParseContext pCtx, Set<ReadEntity> inputs,
       Set<WriteEntity> outputs) throws SemanticException {
     PERF_LOGGER.PerfLogBegin(CLASS_NAME, PerfLogger.SPARK_OPTIMIZE_OPERATOR_TREE);
-    // Sequence of TableScan operators to be walked
-    Deque<Operator<? extends OperatorDesc>> deque = new LinkedList<Operator<? extends OperatorDesc>>();
-    deque.addAll(pCtx.getTopOps().values());
 
-    OptimizeSparkProcContext procCtx = new OptimizeSparkProcContext(conf, pCtx, inputs, outputs, deque);
-    // create a walker which walks the tree in a DFS manner while maintaining
-    // the operator stack.
+    OptimizeSparkProcContext procCtx = new OptimizeSparkProcContext(conf, pCtx, inputs, outputs);
+
+    // Run Spark Dynamic Partition Pruning
+    runDynamicPartitionPruning(procCtx);
+
+    // Annotation OP tree with statistics
+    runStatsAnnotation(procCtx);
+
+    // Run Join releated optimizations
+    runJoinOptimizations(procCtx);
+
+    PERF_LOGGER.PerfLogEnd(CLASS_NAME, PerfLogger.SPARK_OPTIMIZE_OPERATOR_TREE);
+  }
+
+  private void runStatsAnnotation(OptimizeSparkProcContext procCtx) throws SemanticException {
+    new AnnotateWithStatistics().transform(procCtx.getParseContext());
+    new AnnotateWithOpTraits().transform(procCtx.getParseContext());
+  }
+
+  private void runDynamicPartitionPruning(OptimizeSparkProcContext procCtx)
+      throws SemanticException {
+    if (!conf.getBoolVar(HiveConf.ConfVars.SPARK_DYNAMIC_PARTITION_PRUNING)) {
+      return;
+    }
+
+    ParseContext parseContext = procCtx.getParseContext();
+    Map<Rule, NodeProcessor> opRules = new LinkedHashMap<Rule, NodeProcessor>();
+    opRules.put(
+        new RuleRegExp(new String("Dynamic Partition Pruning"),
+            FilterOperator.getOperatorName() + "%"),
+        new DynamicPartitionPruningOptimization());
+
+    // The dispatcher fires the processor corresponding to the closest matching
+    // rule and passes the context along
+    Dispatcher disp = new DefaultRuleDispatcher(null, opRules, procCtx);
+    GraphWalker ogw = new ForwardWalker(disp);
+
+    List<Node> topNodes = new ArrayList<Node>();
+    topNodes.addAll(parseContext.getTopOps().values());
+    ogw.startWalking(topNodes, null);
+
+    // need a new run of the constant folding because we might have created lots
+    // of "and true and true" conditions.
+    if(procCtx.getConf().getBoolVar(HiveConf.ConfVars.HIVEOPTCONSTANTPROPAGATION)) {
+      new ConstantPropagate().transform(parseContext);
+    }
+  }
+
+  private void runJoinOptimizations(OptimizeSparkProcContext procCtx) throws SemanticException {
+    ParseContext pCtx = procCtx.getParseContext();
     Map<Rule, NodeProcessor> opRules = new LinkedHashMap<Rule, NodeProcessor>();
     opRules.put(new RuleRegExp("Set parallelism - ReduceSink",
-      ReduceSinkOperator.getOperatorName() + "%"),
-      new SetSparkReducerParallelism());
+            ReduceSinkOperator.getOperatorName() + "%"),
+        new SetSparkReducerParallelism());
 
     opRules.put(new TypeRule(JoinOperator.class), new SparkJoinOptimizer(pCtx));
 
     opRules.put(new TypeRule(MapJoinOperator.class), new SparkJoinHintOptimizer(pCtx));
 
+    opRules.put(new RuleRegExp("Disabling Dynamic Partition Pruning By Size",
+        SparkPartitionPruningSinkOperator.getOperatorName() + "%"),
+        new SparkRemoveDynamicPruningBySize());
+
     // The dispatcher fires the processor corresponding to the closest matching
     // rule and passes the context along
     Dispatcher disp = new DefaultRuleDispatcher(null, opRules, procCtx);
@@ -127,7 +178,6 @@ public class SparkCompiler extends TaskCompiler {
     ArrayList<Node> topNodes = new ArrayList<Node>();
     topNodes.addAll(pCtx.getTopOps().values());
     ogw.startWalking(topNodes, null);
-    PERF_LOGGER.PerfLogEnd(CLASS_NAME, PerfLogger.SPARK_OPTIMIZE_OPERATOR_TREE);
   }
 
   /**
@@ -138,20 +188,90 @@ public class SparkCompiler extends TaskCompiler {
       List<Task<MoveWork>> mvTask, Set<ReadEntity> inputs, Set<WriteEntity> outputs)
       throws SemanticException {
     PERF_LOGGER.PerfLogBegin(CLASS_NAME, PerfLogger.SPARK_GENERATE_TASK_TREE);
-    GenSparkUtils.getUtils().resetSequenceNumber();
 
-    ParseContext tempParseContext = getParseContext(pCtx, rootTasks);
-    GenSparkWork genSparkWork = new GenSparkWork(GenSparkUtils.getUtils());
+    GenSparkUtils utils = GenSparkUtils.getUtils();
+    utils.resetSequenceNumber();
 
+    ParseContext tempParseContext = getParseContext(pCtx, rootTasks);
     GenSparkProcContext procCtx = new GenSparkProcContext(
         conf, tempParseContext, mvTask, rootTasks, inputs, outputs, pCtx.getTopOps());
 
+    // -------------------------------- First Pass ---------------------------------- //
+    // Identify SparkPartitionPruningSinkOperators, and break OP tree if necessary
+
+    Map<Rule, NodeProcessor> opRules = new LinkedHashMap<Rule, NodeProcessor>();
+    opRules.put(new RuleRegExp("Clone OP tree for PartitionPruningSink",
+            SparkPartitionPruningSinkOperator.getOperatorName() + "%"),
+        new SplitOpTreeForDPP());
+
+    Dispatcher disp = new DefaultRuleDispatcher(null, opRules, procCtx);
+    GraphWalker ogw = new GenSparkWorkWalker(disp, procCtx);
+
+    List<Node> topNodes = new ArrayList<Node>();
+    topNodes.addAll(pCtx.getTopOps().values());
+    ogw.startWalking(topNodes, null);
+
+    // -------------------------------- Second Pass ---------------------------------- //
+    // Process operator tree in two steps: first we process the extra op trees generated
+    // in the first pass. Then we process the main op tree, and the result task will depend
+    // on the task generated in the first pass.
+    topNodes.clear();
+    topNodes.addAll(procCtx.topOps.values());
+    generateTaskTreeHelper(procCtx, topNodes);
+
+    // If this set is not empty, it means we need to generate a separate task for collecting
+    // the partitions used.
+    if (!procCtx.clonedPruningTableScanSet.isEmpty()) {
+      SparkTask pruningTask = SparkUtilities.createSparkTask(conf);
+      SparkTask mainTask = procCtx.currentTask;
+      pruningTask.addDependentTask(procCtx.currentTask);
+      procCtx.rootTasks.remove(procCtx.currentTask);
+      procCtx.rootTasks.add(pruningTask);
+      procCtx.currentTask = pruningTask;
+
+      topNodes.clear();
+      topNodes.addAll(procCtx.clonedPruningTableScanSet);
+      generateTaskTreeHelper(procCtx, topNodes);
+
+      procCtx.currentTask = mainTask;
+    }
+
+    // -------------------------------- Post Pass ---------------------------------- //
+
+    // we need to clone some operator plans and remove union operators still
+    for (BaseWork w : procCtx.workWithUnionOperators) {
+      GenSparkUtils.getUtils().removeUnionOperators(conf, procCtx, w);
+    }
+
+    // we need to fill MapWork with 'local' work and bucket information for SMB Join.
+    GenSparkUtils.getUtils().annotateMapWork(procCtx);
+
+    // finally make sure the file sink operators are set up right
+    for (FileSinkOperator fileSink : procCtx.fileSinkSet) {
+      GenSparkUtils.getUtils().processFileSink(procCtx, fileSink);
+    }
+
+    // Process partition pruning sinks
+    for (Operator<?> prunerSink : procCtx.pruningSinkSet) {
+      utils.processPartitionPruningSink(procCtx, (SparkPartitionPruningSinkOperator) prunerSink);
+    }
+
+    PERF_LOGGER.PerfLogEnd(CLASS_NAME, PerfLogger.SPARK_GENERATE_TASK_TREE);
+  }
+
+  private void generateTaskTreeHelper(GenSparkProcContext procCtx, List<Node> topNodes)
+    throws SemanticException {
     // create a walker which walks the tree in a DFS manner while maintaining
     // the operator stack. The dispatcher generates the plan from the operator tree
     Map<Rule, NodeProcessor> opRules = new LinkedHashMap<Rule, NodeProcessor>();
+    GenSparkWork genSparkWork = new GenSparkWork(GenSparkUtils.getUtils());
+
     opRules.put(new RuleRegExp("Split Work - ReduceSink",
         ReduceSinkOperator.getOperatorName() + "%"), genSparkWork);
 
+    opRules.put(new RuleRegExp("Split Work - SparkPartitionPruningSink",
+        SparkPartitionPruningSinkOperator.getOperatorName() + "%"), genSparkWork);
+
     opRules.put(new TypeRule(MapJoinOperator.class), new SparkReduceSinkMapJoinProc());
 
     opRules.put(new RuleRegExp("Split Work + Move/Merge - FileSink",
@@ -186,8 +306,10 @@ public class SparkCompiler extends TaskCompiler {
      *                         SMBJoinOP
      *
      * Some of the other processors are expecting only one traversal beyond SMBJoinOp.
-     * We need to traverse from the big-table path only, and stop traversing on the small-table path once we reach SMBJoinOp.
-     * Also add some SMB join information to the context, so we can properly annotate the MapWork later on.
+     * We need to traverse from the big-table path only, and stop traversing on the
+     * small-table path once we reach SMBJoinOp.
+     * Also add some SMB join information to the context, so we can properly annotate
+     * the MapWork later on.
      */
     opRules.put(new TypeRule(SMBMapJoinOperator.class),
       new NodeProcessor() {
@@ -219,25 +341,8 @@ public class SparkCompiler extends TaskCompiler {
     // The dispatcher fires the processor corresponding to the closest matching
     // rule and passes the context along
     Dispatcher disp = new DefaultRuleDispatcher(null, opRules, procCtx);
-    List<Node> topNodes = new ArrayList<Node>();
-    topNodes.addAll(pCtx.getTopOps().values());
     GraphWalker ogw = new GenSparkWorkWalker(disp, procCtx);
     ogw.startWalking(topNodes, null);
-
-    // we need to clone some operator plans and remove union operators still
-    for (BaseWork w: procCtx.workWithUnionOperators) {
-      GenSparkUtils.getUtils().removeUnionOperators(conf, procCtx, w);
-    }
-
-    // we need to fill MapWork with 'local' work and bucket information for SMB Join.
-    GenSparkUtils.getUtils().annotateMapWork(procCtx);
-
-    // finally make sure the file sink operators are set up right
-    for (FileSinkOperator fileSink: procCtx.fileSinkSet) {
-      GenSparkUtils.getUtils().processFileSink(procCtx, fileSink);
-    }
-
-    PERF_LOGGER.PerfLogEnd(CLASS_NAME, PerfLogger.SPARK_GENERATE_TASK_TREE);
   }
 
   @Override

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkPartitionPruningSinkOperator.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkPartitionPruningSinkOperator.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkPartitionPruningSinkOperator.java
new file mode 100644
index 0000000..20432c7
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SparkPartitionPruningSinkOperator.java
@@ -0,0 +1,142 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.parse.spark;
+
+import java.io.BufferedOutputStream;
+import java.io.IOException;
+import java.io.ObjectOutputStream;
+import java.util.Collection;
+import java.util.concurrent.Future;
+
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+import org.apache.hadoop.conf.Configuration;
+import org.apache.hadoop.fs.FSDataOutputStream;
+import org.apache.hadoop.fs.FileSystem;
+import org.apache.hadoop.fs.Path;
+import org.apache.hadoop.hive.ql.exec.Operator;
+import org.apache.hadoop.hive.ql.exec.Utilities;
+import org.apache.hadoop.hive.ql.metadata.HiveException;
+import org.apache.hadoop.hive.ql.optimizer.spark.SparkPartitionPruningSinkDesc;
+import org.apache.hadoop.hive.ql.plan.api.OperatorType;
+import org.apache.hadoop.hive.serde2.objectinspector.ObjectInspector;
+import org.apache.hadoop.io.DataOutputBuffer;
+import org.apache.hadoop.io.Writable;
+import org.apache.hadoop.util.ReflectionUtils;
+import org.apache.hadoop.hive.serde2.Serializer;
+
+/**
+ * This operator gets partition info from the upstream operators, and write them
+ * to HDFS. This will later be read at the driver, and used for pruning the partitions
+ * for the big table side.
+ */
+public class SparkPartitionPruningSinkOperator extends Operator<SparkPartitionPruningSinkDesc> {
+
+  @SuppressWarnings("deprecation")
+  protected transient Serializer serializer;
+  protected transient DataOutputBuffer buffer;
+  protected static final Log LOG = LogFactory.getLog(SparkPartitionPruningSinkOperator.class);
+
+  @SuppressWarnings("deprecation")
+  public Collection<Future<?>> initializeOp(Configuration hconf) throws HiveException {
+    Collection<Future<?>> result = super.initializeOp(hconf);
+    serializer = (Serializer) ReflectionUtils.newInstance(
+        conf.getTable().getDeserializerClass(), null);
+    buffer = new DataOutputBuffer();
+    return result;
+  }
+
+  @Override
+  public void process(Object row, int tag) throws HiveException {
+    ObjectInspector rowInspector = inputObjInspectors[0];
+    try {
+      Writable writableRow = serializer.serialize(row, rowInspector);
+      writableRow.write(buffer);
+    } catch (Exception e) {
+      throw new HiveException(e);
+    }
+  }
+
+  @Override
+  public void closeOp(boolean abort) throws HiveException {
+    if (!abort) {
+      try {
+        flushToFile();
+      } catch (Exception e) {
+        throw new HiveException(e);
+      }
+    }
+  }
+
+  private void flushToFile() throws IOException {
+    // write an intermediate file to the specified path
+    // the format of the path is: tmpPath/targetWorkId/sourceWorkId/randInt
+    Path path = conf.getPath();
+    FileSystem fs = path.getFileSystem(this.getConfiguration());
+    fs.mkdirs(path);
+
+    while (true) {
+      path = new Path(path, String.valueOf(Utilities.randGen.nextInt()));
+      if (!fs.exists(path)) {
+        break;
+      }
+    }
+
+    short numOfRepl = fs.getDefaultReplication(path);
+
+    ObjectOutputStream out = null;
+    FSDataOutputStream fsout = null;
+
+    try {
+      fsout = fs.create(path, numOfRepl);
+      out = new ObjectOutputStream(new BufferedOutputStream(fsout, 4096));
+      out.writeUTF(conf.getTargetColumnName());
+      buffer.writeTo(out);
+    } catch (Exception e) {
+      try {
+        fs.delete(path, false);
+      } catch (Exception ex) {
+        LOG.warn("Exception happened while trying to clean partial file.");
+      }
+      throw e;
+    } finally {
+      if (out != null) {
+        LOG.info("Flushed to file: " + path);
+        out.close();
+      } else if (fsout != null) {
+        fsout.close();
+      }
+    }
+  }
+
+  @Override
+  public OperatorType getType() {
+    return OperatorType.SPARKPRUNINGSINK;
+  }
+
+  @Override
+  public String getName() {
+    return getOperatorName();
+  }
+
+  public static String getOperatorName() {
+    return "SPARKPRUNINGSINK";
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SplitOpTreeForDPP.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SplitOpTreeForDPP.java b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SplitOpTreeForDPP.java
new file mode 100644
index 0000000..c140f67
--- /dev/null
+++ b/ql/src/java/org/apache/hadoop/hive/ql/parse/spark/SplitOpTreeForDPP.java
@@ -0,0 +1,151 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.hadoop.hive.ql.parse.spark;
+
+import java.util.HashSet;
+import java.util.LinkedList;
+import java.util.List;
+import java.util.Set;
+import java.util.Stack;
+
+import com.google.common.base.Preconditions;
+import org.apache.hadoop.hive.ql.exec.MapJoinOperator;
+import org.apache.hadoop.hive.ql.exec.Operator;
+import org.apache.hadoop.hive.ql.exec.ReduceSinkOperator;
+import org.apache.hadoop.hive.ql.exec.TableScanOperator;
+import org.apache.hadoop.hive.ql.exec.Utilities;
+import org.apache.hadoop.hive.ql.exec.spark.SparkUtilities;
+import org.apache.hadoop.hive.ql.lib.Node;
+import org.apache.hadoop.hive.ql.lib.NodeProcessor;
+import org.apache.hadoop.hive.ql.lib.NodeProcessorCtx;
+import org.apache.hadoop.hive.ql.parse.SemanticException;
+
+/**
+ * This processor triggers on SparkPartitionPruningSinkOperator. For a operator tree like
+ * this:
+ *
+ * Original Tree:
+ *     TS    TS
+ *      |     |
+ *     FIL   FIL
+ *      |     | \
+ *     RS     RS SEL
+ *       \   /    |
+ *        JOIN   GBY
+ *                |
+ *               SPARKPRUNINGSINK
+ *
+ * It removes the branch containing SPARKPRUNINGSINK from the original operator tree, and splits it into
+ * two separate trees:
+ *
+ * Tree #1:                 Tree #2:
+ *     TS    TS               TS
+ *      |     |                |
+ *     FIL   FIL              FIL
+ *      |     |                |
+ *     RS     RS              SEL
+ *       \   /                 |
+ *       JOIN                 GBY
+ *                             |
+ *                            SPARKPRUNINGSINK
+ *
+ * For MapJoinOperator, this optimizer will not do anything - it should be executed within
+ * the same SparkTask.
+ */
+public class SplitOpTreeForDPP implements NodeProcessor {
+  @Override
+  public Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procCtx,
+                        Object... nodeOutputs) throws SemanticException {
+    SparkPartitionPruningSinkOperator pruningSinkOp = (SparkPartitionPruningSinkOperator) nd;
+    GenSparkProcContext context = (GenSparkProcContext) procCtx;
+
+    // Locate the op where the branch starts
+    // This is guaranteed to succeed since the branch always follow the pattern
+    // as shown in the first picture above.
+    Operator<?> filterOp = pruningSinkOp;
+    Operator<?> selOp = null;
+    while (filterOp != null) {
+      if (filterOp.getNumChild() > 1) {
+        break;
+      } else {
+        selOp = filterOp;
+        filterOp = filterOp.getParentOperators().get(0);
+      }
+    }
+
+    // Check if this is a MapJoin. If so, do not split.
+    for (Operator<?> childOp : filterOp.getChildOperators()) {
+      if (childOp instanceof ReduceSinkOperator &&
+          childOp.getChildOperators().get(0) instanceof MapJoinOperator) {
+        context.pruningSinkSet.add(pruningSinkOp);
+        return null;
+      }
+    }
+
+    List<Operator<?>> roots = new LinkedList<Operator<?>>();
+    collectRoots(roots, pruningSinkOp);
+
+    List<Operator<?>> savedChildOps = filterOp.getChildOperators();
+    filterOp.setChildOperators(Utilities.makeList(selOp));
+
+    // Now clone the tree above selOp
+    List<Operator<?>> newRoots = Utilities.cloneOperatorTree(context.parseContext.getConf(), roots);
+    for (int i = 0; i < roots.size(); i++) {
+      TableScanOperator newTs = (TableScanOperator) newRoots.get(i);
+      TableScanOperator oldTs = (TableScanOperator) roots.get(i);
+      newTs.getConf().setTableMetadata(oldTs.getConf().getTableMetadata());
+    }
+    context.clonedPruningTableScanSet.addAll(newRoots);
+
+    // Restore broken links between operators, and remove the branch from the original tree
+    filterOp.setChildOperators(savedChildOps);
+    filterOp.removeChild(selOp);
+
+    // Find the cloned PruningSink and add it to pruningSinkSet
+    Set<Operator<?>> sinkSet = new HashSet<Operator<?>>();
+    for (Operator<?> root : newRoots) {
+      SparkUtilities.collectOp(sinkSet, root, SparkPartitionPruningSinkOperator.class);
+    }
+    Preconditions.checkArgument(sinkSet.size() == 1,
+        "AssertionError: expected to only contain one SparkPartitionPruningSinkOperator," +
+            " but found " + sinkSet.size());
+    SparkPartitionPruningSinkOperator clonedPruningSinkOp =
+        (SparkPartitionPruningSinkOperator) sinkSet.iterator().next();
+    clonedPruningSinkOp.getConf().setTableScan(pruningSinkOp.getConf().getTableScan());
+    context.pruningSinkSet.add(clonedPruningSinkOp);
+
+    return null;
+  }
+
+  /**
+   * Recursively collect all roots (e.g., table scans) that can be reached via this op.
+   * @param result contains all roots can be reached via op
+   * @param op the op to examine.
+   */
+  private void collectRoots(List<Operator<?>> result, Operator<?> op) {
+    if (op.getNumParent() == 0) {
+      result.add(op);
+    } else {
+      for (Operator<?> parentOp : op.getParentOperators()) {
+        collectRoots(result, parentOp);
+      }
+    }
+  }
+
+}

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/plan/MapWork.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/plan/MapWork.java b/ql/src/java/org/apache/hadoop/hive/ql/plan/MapWork.java
index 3217df2..2cb9257 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/plan/MapWork.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/plan/MapWork.java
@@ -87,6 +87,8 @@ public class MapWork extends BaseWork {
 
   private Path tmpHDFSPath;
 
+  private Path tmpPathForPartitionPruning;
+
   private String inputformat;
 
   private String indexIntermediateFile;
@@ -455,6 +457,14 @@ public class MapWork extends BaseWork {
     this.tmpHDFSPath = tmpHDFSPath;
   }
 
+  public Path getTmpPathForPartitionPruning() {
+    return this.tmpPathForPartitionPruning;
+  }
+
+  public void setTmpPathForPartitionPruning(Path tmpPathForPartitionPruning) {
+    this.tmpPathForPartitionPruning = tmpPathForPartitionPruning;
+  }
+
   public void mergingInto(MapWork mapWork) {
     // currently, this is sole field affecting mergee task
     mapWork.useBucketizedHiveInputFormat |= useBucketizedHiveInputFormat;

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/plan/TableScanDesc.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/plan/TableScanDesc.java b/ql/src/java/org/apache/hadoop/hive/ql/plan/TableScanDesc.java
index 9e9a2a2..d27f3ff 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/plan/TableScanDesc.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/plan/TableScanDesc.java
@@ -103,7 +103,7 @@ public class TableScanDesc extends AbstractOperatorDesc {
 
   private transient TableSample tableSample;
 
-  private transient final Table tableMetadata;
+  private transient Table tableMetadata;
 
   public TableScanDesc() {
     this(null, null);
@@ -284,6 +284,10 @@ public class TableScanDesc extends AbstractOperatorDesc {
     return tableMetadata;
   }
 
+  public void setTableMetadata(Table tableMetadata) {
+    this.tableMetadata = tableMetadata;
+  }
+
   public TableSample getTableSample() {
     return tableSample;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/java/org/apache/hadoop/hive/ql/ppd/SyntheticJoinPredicate.java
----------------------------------------------------------------------
diff --git a/ql/src/java/org/apache/hadoop/hive/ql/ppd/SyntheticJoinPredicate.java b/ql/src/java/org/apache/hadoop/hive/ql/ppd/SyntheticJoinPredicate.java
index 363e49e..32af813 100644
--- a/ql/src/java/org/apache/hadoop/hive/ql/ppd/SyntheticJoinPredicate.java
+++ b/ql/src/java/org/apache/hadoop/hive/ql/ppd/SyntheticJoinPredicate.java
@@ -67,8 +67,18 @@ public class SyntheticJoinPredicate implements Transform {
   @Override
   public ParseContext transform(ParseContext pctx) throws SemanticException {
 
-    if (!pctx.getConf().getVar(ConfVars.HIVE_EXECUTION_ENGINE).equals("tez")
-        || !pctx.getConf().getBoolVar(ConfVars.TEZ_DYNAMIC_PARTITION_PRUNING)) {
+    boolean enabled = false;
+    String queryEngine = pctx.getConf().getVar(ConfVars.HIVE_EXECUTION_ENGINE);
+
+    if (queryEngine.equals("tez")
+        && pctx.getConf().getBoolVar(ConfVars.TEZ_DYNAMIC_PARTITION_PRUNING)) {
+      enabled = true;
+    } else if ((queryEngine.equals("spark")
+        && pctx.getConf().getBoolVar(ConfVars.SPARK_DYNAMIC_PARTITION_PRUNING))) {
+      enabled = true;
+    }
+
+    if (!enabled) {
       return pctx;
     }
 


[14/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService.h b/service/src/gen/thrift/gen-cpp/TCLIService.h
index 030475b..29a9f4a 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService.h
+++ b/service/src/gen/thrift/gen-cpp/TCLIService.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -124,24 +124,26 @@ class TCLIServiceNull : virtual public TCLIServiceIf {
 
 typedef struct _TCLIService_OpenSession_args__isset {
   _TCLIService_OpenSession_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_OpenSession_args__isset;
 
 class TCLIService_OpenSession_args {
  public:
 
+  static const char* ascii_fingerprint; // = "657FF0677838A57698AD9D58A923940A";
+  static const uint8_t binary_fingerprint[16]; // = {0x65,0x7F,0xF0,0x67,0x78,0x38,0xA5,0x76,0x98,0xAD,0x9D,0x58,0xA9,0x23,0x94,0x0A};
+
+  TCLIService_OpenSession_args(const TCLIService_OpenSession_args&);
+  TCLIService_OpenSession_args& operator=(const TCLIService_OpenSession_args&);
   TCLIService_OpenSession_args() {
   }
 
-  virtual ~TCLIService_OpenSession_args() throw() {}
-
+  virtual ~TCLIService_OpenSession_args() throw();
   TOpenSessionReq req;
 
   _TCLIService_OpenSession_args__isset __isset;
 
-  void __set_req(const TOpenSessionReq& val) {
-    req = val;
-  }
+  void __set_req(const TOpenSessionReq& val);
 
   bool operator == (const TCLIService_OpenSession_args & rhs) const
   {
@@ -158,41 +160,47 @@ class TCLIService_OpenSession_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_OpenSession_args& obj);
 };
 
 
 class TCLIService_OpenSession_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "657FF0677838A57698AD9D58A923940A";
+  static const uint8_t binary_fingerprint[16]; // = {0x65,0x7F,0xF0,0x67,0x78,0x38,0xA5,0x76,0x98,0xAD,0x9D,0x58,0xA9,0x23,0x94,0x0A};
 
-  virtual ~TCLIService_OpenSession_pargs() throw() {}
 
+  virtual ~TCLIService_OpenSession_pargs() throw();
   const TOpenSessionReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_OpenSession_pargs& obj);
 };
 
 typedef struct _TCLIService_OpenSession_result__isset {
   _TCLIService_OpenSession_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_OpenSession_result__isset;
 
 class TCLIService_OpenSession_result {
  public:
 
+  static const char* ascii_fingerprint; // = "C55268D57D6DC6A256619A7DB419699E";
+  static const uint8_t binary_fingerprint[16]; // = {0xC5,0x52,0x68,0xD5,0x7D,0x6D,0xC6,0xA2,0x56,0x61,0x9A,0x7D,0xB4,0x19,0x69,0x9E};
+
+  TCLIService_OpenSession_result(const TCLIService_OpenSession_result&);
+  TCLIService_OpenSession_result& operator=(const TCLIService_OpenSession_result&);
   TCLIService_OpenSession_result() {
   }
 
-  virtual ~TCLIService_OpenSession_result() throw() {}
-
+  virtual ~TCLIService_OpenSession_result() throw();
   TOpenSessionResp success;
 
   _TCLIService_OpenSession_result__isset __isset;
 
-  void __set_success(const TOpenSessionResp& val) {
-    success = val;
-  }
+  void __set_success(const TOpenSessionResp& val);
 
   bool operator == (const TCLIService_OpenSession_result & rhs) const
   {
@@ -209,47 +217,53 @@ class TCLIService_OpenSession_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_OpenSession_result& obj);
 };
 
 typedef struct _TCLIService_OpenSession_presult__isset {
   _TCLIService_OpenSession_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_OpenSession_presult__isset;
 
 class TCLIService_OpenSession_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "C55268D57D6DC6A256619A7DB419699E";
+  static const uint8_t binary_fingerprint[16]; // = {0xC5,0x52,0x68,0xD5,0x7D,0x6D,0xC6,0xA2,0x56,0x61,0x9A,0x7D,0xB4,0x19,0x69,0x9E};
 
-  virtual ~TCLIService_OpenSession_presult() throw() {}
 
+  virtual ~TCLIService_OpenSession_presult() throw();
   TOpenSessionResp* success;
 
   _TCLIService_OpenSession_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_OpenSession_presult& obj);
 };
 
 typedef struct _TCLIService_CloseSession_args__isset {
   _TCLIService_CloseSession_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_CloseSession_args__isset;
 
 class TCLIService_CloseSession_args {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
+
+  TCLIService_CloseSession_args(const TCLIService_CloseSession_args&);
+  TCLIService_CloseSession_args& operator=(const TCLIService_CloseSession_args&);
   TCLIService_CloseSession_args() {
   }
 
-  virtual ~TCLIService_CloseSession_args() throw() {}
-
+  virtual ~TCLIService_CloseSession_args() throw();
   TCloseSessionReq req;
 
   _TCLIService_CloseSession_args__isset __isset;
 
-  void __set_req(const TCloseSessionReq& val) {
-    req = val;
-  }
+  void __set_req(const TCloseSessionReq& val);
 
   bool operator == (const TCLIService_CloseSession_args & rhs) const
   {
@@ -266,41 +280,47 @@ class TCLIService_CloseSession_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseSession_args& obj);
 };
 
 
 class TCLIService_CloseSession_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
 
-  virtual ~TCLIService_CloseSession_pargs() throw() {}
 
+  virtual ~TCLIService_CloseSession_pargs() throw();
   const TCloseSessionReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseSession_pargs& obj);
 };
 
 typedef struct _TCLIService_CloseSession_result__isset {
   _TCLIService_CloseSession_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CloseSession_result__isset;
 
 class TCLIService_CloseSession_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
+
+  TCLIService_CloseSession_result(const TCLIService_CloseSession_result&);
+  TCLIService_CloseSession_result& operator=(const TCLIService_CloseSession_result&);
   TCLIService_CloseSession_result() {
   }
 
-  virtual ~TCLIService_CloseSession_result() throw() {}
-
+  virtual ~TCLIService_CloseSession_result() throw();
   TCloseSessionResp success;
 
   _TCLIService_CloseSession_result__isset __isset;
 
-  void __set_success(const TCloseSessionResp& val) {
-    success = val;
-  }
+  void __set_success(const TCloseSessionResp& val);
 
   bool operator == (const TCLIService_CloseSession_result & rhs) const
   {
@@ -317,47 +337,53 @@ class TCLIService_CloseSession_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseSession_result& obj);
 };
 
 typedef struct _TCLIService_CloseSession_presult__isset {
   _TCLIService_CloseSession_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CloseSession_presult__isset;
 
 class TCLIService_CloseSession_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
 
-  virtual ~TCLIService_CloseSession_presult() throw() {}
 
+  virtual ~TCLIService_CloseSession_presult() throw();
   TCloseSessionResp* success;
 
   _TCLIService_CloseSession_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseSession_presult& obj);
 };
 
 typedef struct _TCLIService_GetInfo_args__isset {
   _TCLIService_GetInfo_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetInfo_args__isset;
 
 class TCLIService_GetInfo_args {
  public:
 
+  static const char* ascii_fingerprint; // = "482A174DD6064955A19F28C5395E27FA";
+  static const uint8_t binary_fingerprint[16]; // = {0x48,0x2A,0x17,0x4D,0xD6,0x06,0x49,0x55,0xA1,0x9F,0x28,0xC5,0x39,0x5E,0x27,0xFA};
+
+  TCLIService_GetInfo_args(const TCLIService_GetInfo_args&);
+  TCLIService_GetInfo_args& operator=(const TCLIService_GetInfo_args&);
   TCLIService_GetInfo_args() {
   }
 
-  virtual ~TCLIService_GetInfo_args() throw() {}
-
+  virtual ~TCLIService_GetInfo_args() throw();
   TGetInfoReq req;
 
   _TCLIService_GetInfo_args__isset __isset;
 
-  void __set_req(const TGetInfoReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetInfoReq& val);
 
   bool operator == (const TCLIService_GetInfo_args & rhs) const
   {
@@ -374,41 +400,47 @@ class TCLIService_GetInfo_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetInfo_args& obj);
 };
 
 
 class TCLIService_GetInfo_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "482A174DD6064955A19F28C5395E27FA";
+  static const uint8_t binary_fingerprint[16]; // = {0x48,0x2A,0x17,0x4D,0xD6,0x06,0x49,0x55,0xA1,0x9F,0x28,0xC5,0x39,0x5E,0x27,0xFA};
 
-  virtual ~TCLIService_GetInfo_pargs() throw() {}
 
+  virtual ~TCLIService_GetInfo_pargs() throw();
   const TGetInfoReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetInfo_pargs& obj);
 };
 
 typedef struct _TCLIService_GetInfo_result__isset {
   _TCLIService_GetInfo_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetInfo_result__isset;
 
 class TCLIService_GetInfo_result {
  public:
 
+  static const char* ascii_fingerprint; // = "95AE9E06990A55202EF5D96DABE20D75";
+  static const uint8_t binary_fingerprint[16]; // = {0x95,0xAE,0x9E,0x06,0x99,0x0A,0x55,0x20,0x2E,0xF5,0xD9,0x6D,0xAB,0xE2,0x0D,0x75};
+
+  TCLIService_GetInfo_result(const TCLIService_GetInfo_result&);
+  TCLIService_GetInfo_result& operator=(const TCLIService_GetInfo_result&);
   TCLIService_GetInfo_result() {
   }
 
-  virtual ~TCLIService_GetInfo_result() throw() {}
-
+  virtual ~TCLIService_GetInfo_result() throw();
   TGetInfoResp success;
 
   _TCLIService_GetInfo_result__isset __isset;
 
-  void __set_success(const TGetInfoResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetInfoResp& val);
 
   bool operator == (const TCLIService_GetInfo_result & rhs) const
   {
@@ -425,47 +457,53 @@ class TCLIService_GetInfo_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetInfo_result& obj);
 };
 
 typedef struct _TCLIService_GetInfo_presult__isset {
   _TCLIService_GetInfo_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetInfo_presult__isset;
 
 class TCLIService_GetInfo_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "95AE9E06990A55202EF5D96DABE20D75";
+  static const uint8_t binary_fingerprint[16]; // = {0x95,0xAE,0x9E,0x06,0x99,0x0A,0x55,0x20,0x2E,0xF5,0xD9,0x6D,0xAB,0xE2,0x0D,0x75};
 
-  virtual ~TCLIService_GetInfo_presult() throw() {}
 
+  virtual ~TCLIService_GetInfo_presult() throw();
   TGetInfoResp* success;
 
   _TCLIService_GetInfo_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetInfo_presult& obj);
 };
 
 typedef struct _TCLIService_ExecuteStatement_args__isset {
   _TCLIService_ExecuteStatement_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_ExecuteStatement_args__isset;
 
 class TCLIService_ExecuteStatement_args {
  public:
 
+  static const char* ascii_fingerprint; // = "BD5534ACDA7A523F638927AC476C2173";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x55,0x34,0xAC,0xDA,0x7A,0x52,0x3F,0x63,0x89,0x27,0xAC,0x47,0x6C,0x21,0x73};
+
+  TCLIService_ExecuteStatement_args(const TCLIService_ExecuteStatement_args&);
+  TCLIService_ExecuteStatement_args& operator=(const TCLIService_ExecuteStatement_args&);
   TCLIService_ExecuteStatement_args() {
   }
 
-  virtual ~TCLIService_ExecuteStatement_args() throw() {}
-
+  virtual ~TCLIService_ExecuteStatement_args() throw();
   TExecuteStatementReq req;
 
   _TCLIService_ExecuteStatement_args__isset __isset;
 
-  void __set_req(const TExecuteStatementReq& val) {
-    req = val;
-  }
+  void __set_req(const TExecuteStatementReq& val);
 
   bool operator == (const TCLIService_ExecuteStatement_args & rhs) const
   {
@@ -482,41 +520,47 @@ class TCLIService_ExecuteStatement_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_ExecuteStatement_args& obj);
 };
 
 
 class TCLIService_ExecuteStatement_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "BD5534ACDA7A523F638927AC476C2173";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x55,0x34,0xAC,0xDA,0x7A,0x52,0x3F,0x63,0x89,0x27,0xAC,0x47,0x6C,0x21,0x73};
 
-  virtual ~TCLIService_ExecuteStatement_pargs() throw() {}
 
+  virtual ~TCLIService_ExecuteStatement_pargs() throw();
   const TExecuteStatementReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_ExecuteStatement_pargs& obj);
 };
 
 typedef struct _TCLIService_ExecuteStatement_result__isset {
   _TCLIService_ExecuteStatement_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_ExecuteStatement_result__isset;
 
 class TCLIService_ExecuteStatement_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_ExecuteStatement_result(const TCLIService_ExecuteStatement_result&);
+  TCLIService_ExecuteStatement_result& operator=(const TCLIService_ExecuteStatement_result&);
   TCLIService_ExecuteStatement_result() {
   }
 
-  virtual ~TCLIService_ExecuteStatement_result() throw() {}
-
+  virtual ~TCLIService_ExecuteStatement_result() throw();
   TExecuteStatementResp success;
 
   _TCLIService_ExecuteStatement_result__isset __isset;
 
-  void __set_success(const TExecuteStatementResp& val) {
-    success = val;
-  }
+  void __set_success(const TExecuteStatementResp& val);
 
   bool operator == (const TCLIService_ExecuteStatement_result & rhs) const
   {
@@ -533,47 +577,53 @@ class TCLIService_ExecuteStatement_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_ExecuteStatement_result& obj);
 };
 
 typedef struct _TCLIService_ExecuteStatement_presult__isset {
   _TCLIService_ExecuteStatement_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_ExecuteStatement_presult__isset;
 
 class TCLIService_ExecuteStatement_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_ExecuteStatement_presult() throw() {}
 
+  virtual ~TCLIService_ExecuteStatement_presult() throw();
   TExecuteStatementResp* success;
 
   _TCLIService_ExecuteStatement_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_ExecuteStatement_presult& obj);
 };
 
 typedef struct _TCLIService_GetTypeInfo_args__isset {
   _TCLIService_GetTypeInfo_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetTypeInfo_args__isset;
 
 class TCLIService_GetTypeInfo_args {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
+
+  TCLIService_GetTypeInfo_args(const TCLIService_GetTypeInfo_args&);
+  TCLIService_GetTypeInfo_args& operator=(const TCLIService_GetTypeInfo_args&);
   TCLIService_GetTypeInfo_args() {
   }
 
-  virtual ~TCLIService_GetTypeInfo_args() throw() {}
-
+  virtual ~TCLIService_GetTypeInfo_args() throw();
   TGetTypeInfoReq req;
 
   _TCLIService_GetTypeInfo_args__isset __isset;
 
-  void __set_req(const TGetTypeInfoReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetTypeInfoReq& val);
 
   bool operator == (const TCLIService_GetTypeInfo_args & rhs) const
   {
@@ -590,41 +640,47 @@ class TCLIService_GetTypeInfo_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTypeInfo_args& obj);
 };
 
 
 class TCLIService_GetTypeInfo_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
 
-  virtual ~TCLIService_GetTypeInfo_pargs() throw() {}
 
+  virtual ~TCLIService_GetTypeInfo_pargs() throw();
   const TGetTypeInfoReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTypeInfo_pargs& obj);
 };
 
 typedef struct _TCLIService_GetTypeInfo_result__isset {
   _TCLIService_GetTypeInfo_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTypeInfo_result__isset;
 
 class TCLIService_GetTypeInfo_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetTypeInfo_result(const TCLIService_GetTypeInfo_result&);
+  TCLIService_GetTypeInfo_result& operator=(const TCLIService_GetTypeInfo_result&);
   TCLIService_GetTypeInfo_result() {
   }
 
-  virtual ~TCLIService_GetTypeInfo_result() throw() {}
-
+  virtual ~TCLIService_GetTypeInfo_result() throw();
   TGetTypeInfoResp success;
 
   _TCLIService_GetTypeInfo_result__isset __isset;
 
-  void __set_success(const TGetTypeInfoResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetTypeInfoResp& val);
 
   bool operator == (const TCLIService_GetTypeInfo_result & rhs) const
   {
@@ -641,47 +697,53 @@ class TCLIService_GetTypeInfo_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTypeInfo_result& obj);
 };
 
 typedef struct _TCLIService_GetTypeInfo_presult__isset {
   _TCLIService_GetTypeInfo_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTypeInfo_presult__isset;
 
 class TCLIService_GetTypeInfo_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetTypeInfo_presult() throw() {}
 
+  virtual ~TCLIService_GetTypeInfo_presult() throw();
   TGetTypeInfoResp* success;
 
   _TCLIService_GetTypeInfo_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTypeInfo_presult& obj);
 };
 
 typedef struct _TCLIService_GetCatalogs_args__isset {
   _TCLIService_GetCatalogs_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetCatalogs_args__isset;
 
 class TCLIService_GetCatalogs_args {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
+
+  TCLIService_GetCatalogs_args(const TCLIService_GetCatalogs_args&);
+  TCLIService_GetCatalogs_args& operator=(const TCLIService_GetCatalogs_args&);
   TCLIService_GetCatalogs_args() {
   }
 
-  virtual ~TCLIService_GetCatalogs_args() throw() {}
-
+  virtual ~TCLIService_GetCatalogs_args() throw();
   TGetCatalogsReq req;
 
   _TCLIService_GetCatalogs_args__isset __isset;
 
-  void __set_req(const TGetCatalogsReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetCatalogsReq& val);
 
   bool operator == (const TCLIService_GetCatalogs_args & rhs) const
   {
@@ -698,41 +760,47 @@ class TCLIService_GetCatalogs_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetCatalogs_args& obj);
 };
 
 
 class TCLIService_GetCatalogs_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
 
-  virtual ~TCLIService_GetCatalogs_pargs() throw() {}
 
+  virtual ~TCLIService_GetCatalogs_pargs() throw();
   const TGetCatalogsReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetCatalogs_pargs& obj);
 };
 
 typedef struct _TCLIService_GetCatalogs_result__isset {
   _TCLIService_GetCatalogs_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetCatalogs_result__isset;
 
 class TCLIService_GetCatalogs_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetCatalogs_result(const TCLIService_GetCatalogs_result&);
+  TCLIService_GetCatalogs_result& operator=(const TCLIService_GetCatalogs_result&);
   TCLIService_GetCatalogs_result() {
   }
 
-  virtual ~TCLIService_GetCatalogs_result() throw() {}
-
+  virtual ~TCLIService_GetCatalogs_result() throw();
   TGetCatalogsResp success;
 
   _TCLIService_GetCatalogs_result__isset __isset;
 
-  void __set_success(const TGetCatalogsResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetCatalogsResp& val);
 
   bool operator == (const TCLIService_GetCatalogs_result & rhs) const
   {
@@ -749,47 +817,53 @@ class TCLIService_GetCatalogs_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetCatalogs_result& obj);
 };
 
 typedef struct _TCLIService_GetCatalogs_presult__isset {
   _TCLIService_GetCatalogs_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetCatalogs_presult__isset;
 
 class TCLIService_GetCatalogs_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetCatalogs_presult() throw() {}
 
+  virtual ~TCLIService_GetCatalogs_presult() throw();
   TGetCatalogsResp* success;
 
   _TCLIService_GetCatalogs_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetCatalogs_presult& obj);
 };
 
 typedef struct _TCLIService_GetSchemas_args__isset {
   _TCLIService_GetSchemas_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetSchemas_args__isset;
 
 class TCLIService_GetSchemas_args {
  public:
 
+  static const char* ascii_fingerprint; // = "34B9FACB4B4C34ABAEDCF0A2B60345DE";
+  static const uint8_t binary_fingerprint[16]; // = {0x34,0xB9,0xFA,0xCB,0x4B,0x4C,0x34,0xAB,0xAE,0xDC,0xF0,0xA2,0xB6,0x03,0x45,0xDE};
+
+  TCLIService_GetSchemas_args(const TCLIService_GetSchemas_args&);
+  TCLIService_GetSchemas_args& operator=(const TCLIService_GetSchemas_args&);
   TCLIService_GetSchemas_args() {
   }
 
-  virtual ~TCLIService_GetSchemas_args() throw() {}
-
+  virtual ~TCLIService_GetSchemas_args() throw();
   TGetSchemasReq req;
 
   _TCLIService_GetSchemas_args__isset __isset;
 
-  void __set_req(const TGetSchemasReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetSchemasReq& val);
 
   bool operator == (const TCLIService_GetSchemas_args & rhs) const
   {
@@ -806,41 +880,47 @@ class TCLIService_GetSchemas_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetSchemas_args& obj);
 };
 
 
 class TCLIService_GetSchemas_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "34B9FACB4B4C34ABAEDCF0A2B60345DE";
+  static const uint8_t binary_fingerprint[16]; // = {0x34,0xB9,0xFA,0xCB,0x4B,0x4C,0x34,0xAB,0xAE,0xDC,0xF0,0xA2,0xB6,0x03,0x45,0xDE};
 
-  virtual ~TCLIService_GetSchemas_pargs() throw() {}
 
+  virtual ~TCLIService_GetSchemas_pargs() throw();
   const TGetSchemasReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetSchemas_pargs& obj);
 };
 
 typedef struct _TCLIService_GetSchemas_result__isset {
   _TCLIService_GetSchemas_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetSchemas_result__isset;
 
 class TCLIService_GetSchemas_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetSchemas_result(const TCLIService_GetSchemas_result&);
+  TCLIService_GetSchemas_result& operator=(const TCLIService_GetSchemas_result&);
   TCLIService_GetSchemas_result() {
   }
 
-  virtual ~TCLIService_GetSchemas_result() throw() {}
-
+  virtual ~TCLIService_GetSchemas_result() throw();
   TGetSchemasResp success;
 
   _TCLIService_GetSchemas_result__isset __isset;
 
-  void __set_success(const TGetSchemasResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetSchemasResp& val);
 
   bool operator == (const TCLIService_GetSchemas_result & rhs) const
   {
@@ -857,47 +937,53 @@ class TCLIService_GetSchemas_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetSchemas_result& obj);
 };
 
 typedef struct _TCLIService_GetSchemas_presult__isset {
   _TCLIService_GetSchemas_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetSchemas_presult__isset;
 
 class TCLIService_GetSchemas_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetSchemas_presult() throw() {}
 
+  virtual ~TCLIService_GetSchemas_presult() throw();
   TGetSchemasResp* success;
 
   _TCLIService_GetSchemas_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetSchemas_presult& obj);
 };
 
 typedef struct _TCLIService_GetTables_args__isset {
   _TCLIService_GetTables_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetTables_args__isset;
 
 class TCLIService_GetTables_args {
  public:
 
+  static const char* ascii_fingerprint; // = "58075D8350502C9B1F3532079C1CF7A6";
+  static const uint8_t binary_fingerprint[16]; // = {0x58,0x07,0x5D,0x83,0x50,0x50,0x2C,0x9B,0x1F,0x35,0x32,0x07,0x9C,0x1C,0xF7,0xA6};
+
+  TCLIService_GetTables_args(const TCLIService_GetTables_args&);
+  TCLIService_GetTables_args& operator=(const TCLIService_GetTables_args&);
   TCLIService_GetTables_args() {
   }
 
-  virtual ~TCLIService_GetTables_args() throw() {}
-
+  virtual ~TCLIService_GetTables_args() throw();
   TGetTablesReq req;
 
   _TCLIService_GetTables_args__isset __isset;
 
-  void __set_req(const TGetTablesReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetTablesReq& val);
 
   bool operator == (const TCLIService_GetTables_args & rhs) const
   {
@@ -914,41 +1000,47 @@ class TCLIService_GetTables_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTables_args& obj);
 };
 
 
 class TCLIService_GetTables_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "58075D8350502C9B1F3532079C1CF7A6";
+  static const uint8_t binary_fingerprint[16]; // = {0x58,0x07,0x5D,0x83,0x50,0x50,0x2C,0x9B,0x1F,0x35,0x32,0x07,0x9C,0x1C,0xF7,0xA6};
 
-  virtual ~TCLIService_GetTables_pargs() throw() {}
 
+  virtual ~TCLIService_GetTables_pargs() throw();
   const TGetTablesReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTables_pargs& obj);
 };
 
 typedef struct _TCLIService_GetTables_result__isset {
   _TCLIService_GetTables_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTables_result__isset;
 
 class TCLIService_GetTables_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetTables_result(const TCLIService_GetTables_result&);
+  TCLIService_GetTables_result& operator=(const TCLIService_GetTables_result&);
   TCLIService_GetTables_result() {
   }
 
-  virtual ~TCLIService_GetTables_result() throw() {}
-
+  virtual ~TCLIService_GetTables_result() throw();
   TGetTablesResp success;
 
   _TCLIService_GetTables_result__isset __isset;
 
-  void __set_success(const TGetTablesResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetTablesResp& val);
 
   bool operator == (const TCLIService_GetTables_result & rhs) const
   {
@@ -965,47 +1057,53 @@ class TCLIService_GetTables_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTables_result& obj);
 };
 
 typedef struct _TCLIService_GetTables_presult__isset {
   _TCLIService_GetTables_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTables_presult__isset;
 
 class TCLIService_GetTables_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetTables_presult() throw() {}
 
+  virtual ~TCLIService_GetTables_presult() throw();
   TGetTablesResp* success;
 
   _TCLIService_GetTables_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTables_presult& obj);
 };
 
 typedef struct _TCLIService_GetTableTypes_args__isset {
   _TCLIService_GetTableTypes_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetTableTypes_args__isset;
 
 class TCLIService_GetTableTypes_args {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
+
+  TCLIService_GetTableTypes_args(const TCLIService_GetTableTypes_args&);
+  TCLIService_GetTableTypes_args& operator=(const TCLIService_GetTableTypes_args&);
   TCLIService_GetTableTypes_args() {
   }
 
-  virtual ~TCLIService_GetTableTypes_args() throw() {}
-
+  virtual ~TCLIService_GetTableTypes_args() throw();
   TGetTableTypesReq req;
 
   _TCLIService_GetTableTypes_args__isset __isset;
 
-  void __set_req(const TGetTableTypesReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetTableTypesReq& val);
 
   bool operator == (const TCLIService_GetTableTypes_args & rhs) const
   {
@@ -1022,41 +1120,47 @@ class TCLIService_GetTableTypes_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTableTypes_args& obj);
 };
 
 
 class TCLIService_GetTableTypes_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "FD7076C37D193E2A343D9691B59D94EC";
+  static const uint8_t binary_fingerprint[16]; // = {0xFD,0x70,0x76,0xC3,0x7D,0x19,0x3E,0x2A,0x34,0x3D,0x96,0x91,0xB5,0x9D,0x94,0xEC};
 
-  virtual ~TCLIService_GetTableTypes_pargs() throw() {}
 
+  virtual ~TCLIService_GetTableTypes_pargs() throw();
   const TGetTableTypesReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTableTypes_pargs& obj);
 };
 
 typedef struct _TCLIService_GetTableTypes_result__isset {
   _TCLIService_GetTableTypes_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTableTypes_result__isset;
 
 class TCLIService_GetTableTypes_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetTableTypes_result(const TCLIService_GetTableTypes_result&);
+  TCLIService_GetTableTypes_result& operator=(const TCLIService_GetTableTypes_result&);
   TCLIService_GetTableTypes_result() {
   }
 
-  virtual ~TCLIService_GetTableTypes_result() throw() {}
-
+  virtual ~TCLIService_GetTableTypes_result() throw();
   TGetTableTypesResp success;
 
   _TCLIService_GetTableTypes_result__isset __isset;
 
-  void __set_success(const TGetTableTypesResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetTableTypesResp& val);
 
   bool operator == (const TCLIService_GetTableTypes_result & rhs) const
   {
@@ -1073,47 +1177,53 @@ class TCLIService_GetTableTypes_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTableTypes_result& obj);
 };
 
 typedef struct _TCLIService_GetTableTypes_presult__isset {
   _TCLIService_GetTableTypes_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetTableTypes_presult__isset;
 
 class TCLIService_GetTableTypes_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetTableTypes_presult() throw() {}
 
+  virtual ~TCLIService_GetTableTypes_presult() throw();
   TGetTableTypesResp* success;
 
   _TCLIService_GetTableTypes_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetTableTypes_presult& obj);
 };
 
 typedef struct _TCLIService_GetColumns_args__isset {
   _TCLIService_GetColumns_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetColumns_args__isset;
 
 class TCLIService_GetColumns_args {
  public:
 
+  static const char* ascii_fingerprint; // = "7894A0356591B039C72040E21BAAC3E3";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x94,0xA0,0x35,0x65,0x91,0xB0,0x39,0xC7,0x20,0x40,0xE2,0x1B,0xAA,0xC3,0xE3};
+
+  TCLIService_GetColumns_args(const TCLIService_GetColumns_args&);
+  TCLIService_GetColumns_args& operator=(const TCLIService_GetColumns_args&);
   TCLIService_GetColumns_args() {
   }
 
-  virtual ~TCLIService_GetColumns_args() throw() {}
-
+  virtual ~TCLIService_GetColumns_args() throw();
   TGetColumnsReq req;
 
   _TCLIService_GetColumns_args__isset __isset;
 
-  void __set_req(const TGetColumnsReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetColumnsReq& val);
 
   bool operator == (const TCLIService_GetColumns_args & rhs) const
   {
@@ -1130,41 +1240,47 @@ class TCLIService_GetColumns_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetColumns_args& obj);
 };
 
 
 class TCLIService_GetColumns_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "7894A0356591B039C72040E21BAAC3E3";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x94,0xA0,0x35,0x65,0x91,0xB0,0x39,0xC7,0x20,0x40,0xE2,0x1B,0xAA,0xC3,0xE3};
 
-  virtual ~TCLIService_GetColumns_pargs() throw() {}
 
+  virtual ~TCLIService_GetColumns_pargs() throw();
   const TGetColumnsReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetColumns_pargs& obj);
 };
 
 typedef struct _TCLIService_GetColumns_result__isset {
   _TCLIService_GetColumns_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetColumns_result__isset;
 
 class TCLIService_GetColumns_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetColumns_result(const TCLIService_GetColumns_result&);
+  TCLIService_GetColumns_result& operator=(const TCLIService_GetColumns_result&);
   TCLIService_GetColumns_result() {
   }
 
-  virtual ~TCLIService_GetColumns_result() throw() {}
-
+  virtual ~TCLIService_GetColumns_result() throw();
   TGetColumnsResp success;
 
   _TCLIService_GetColumns_result__isset __isset;
 
-  void __set_success(const TGetColumnsResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetColumnsResp& val);
 
   bool operator == (const TCLIService_GetColumns_result & rhs) const
   {
@@ -1181,47 +1297,53 @@ class TCLIService_GetColumns_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetColumns_result& obj);
 };
 
 typedef struct _TCLIService_GetColumns_presult__isset {
   _TCLIService_GetColumns_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetColumns_presult__isset;
 
 class TCLIService_GetColumns_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetColumns_presult() throw() {}
 
+  virtual ~TCLIService_GetColumns_presult() throw();
   TGetColumnsResp* success;
 
   _TCLIService_GetColumns_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetColumns_presult& obj);
 };
 
 typedef struct _TCLIService_GetFunctions_args__isset {
   _TCLIService_GetFunctions_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetFunctions_args__isset;
 
 class TCLIService_GetFunctions_args {
  public:
 
+  static const char* ascii_fingerprint; // = "AC28BA383D0EC96F55B7C42FA3E1AF52";
+  static const uint8_t binary_fingerprint[16]; // = {0xAC,0x28,0xBA,0x38,0x3D,0x0E,0xC9,0x6F,0x55,0xB7,0xC4,0x2F,0xA3,0xE1,0xAF,0x52};
+
+  TCLIService_GetFunctions_args(const TCLIService_GetFunctions_args&);
+  TCLIService_GetFunctions_args& operator=(const TCLIService_GetFunctions_args&);
   TCLIService_GetFunctions_args() {
   }
 
-  virtual ~TCLIService_GetFunctions_args() throw() {}
-
+  virtual ~TCLIService_GetFunctions_args() throw();
   TGetFunctionsReq req;
 
   _TCLIService_GetFunctions_args__isset __isset;
 
-  void __set_req(const TGetFunctionsReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetFunctionsReq& val);
 
   bool operator == (const TCLIService_GetFunctions_args & rhs) const
   {
@@ -1238,41 +1360,47 @@ class TCLIService_GetFunctions_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetFunctions_args& obj);
 };
 
 
 class TCLIService_GetFunctions_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "AC28BA383D0EC96F55B7C42FA3E1AF52";
+  static const uint8_t binary_fingerprint[16]; // = {0xAC,0x28,0xBA,0x38,0x3D,0x0E,0xC9,0x6F,0x55,0xB7,0xC4,0x2F,0xA3,0xE1,0xAF,0x52};
 
-  virtual ~TCLIService_GetFunctions_pargs() throw() {}
 
+  virtual ~TCLIService_GetFunctions_pargs() throw();
   const TGetFunctionsReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetFunctions_pargs& obj);
 };
 
 typedef struct _TCLIService_GetFunctions_result__isset {
   _TCLIService_GetFunctions_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetFunctions_result__isset;
 
 class TCLIService_GetFunctions_result {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
+
+  TCLIService_GetFunctions_result(const TCLIService_GetFunctions_result&);
+  TCLIService_GetFunctions_result& operator=(const TCLIService_GetFunctions_result&);
   TCLIService_GetFunctions_result() {
   }
 
-  virtual ~TCLIService_GetFunctions_result() throw() {}
-
+  virtual ~TCLIService_GetFunctions_result() throw();
   TGetFunctionsResp success;
 
   _TCLIService_GetFunctions_result__isset __isset;
 
-  void __set_success(const TGetFunctionsResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetFunctionsResp& val);
 
   bool operator == (const TCLIService_GetFunctions_result & rhs) const
   {
@@ -1289,47 +1417,53 @@ class TCLIService_GetFunctions_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetFunctions_result& obj);
 };
 
 typedef struct _TCLIService_GetFunctions_presult__isset {
   _TCLIService_GetFunctions_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetFunctions_presult__isset;
 
 class TCLIService_GetFunctions_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "783BF5EE3B1FEAC8DF5FDAEF1F551CDF";
+  static const uint8_t binary_fingerprint[16]; // = {0x78,0x3B,0xF5,0xEE,0x3B,0x1F,0xEA,0xC8,0xDF,0x5F,0xDA,0xEF,0x1F,0x55,0x1C,0xDF};
 
-  virtual ~TCLIService_GetFunctions_presult() throw() {}
 
+  virtual ~TCLIService_GetFunctions_presult() throw();
   TGetFunctionsResp* success;
 
   _TCLIService_GetFunctions_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetFunctions_presult& obj);
 };
 
 typedef struct _TCLIService_GetOperationStatus_args__isset {
   _TCLIService_GetOperationStatus_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetOperationStatus_args__isset;
 
 class TCLIService_GetOperationStatus_args {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
+
+  TCLIService_GetOperationStatus_args(const TCLIService_GetOperationStatus_args&);
+  TCLIService_GetOperationStatus_args& operator=(const TCLIService_GetOperationStatus_args&);
   TCLIService_GetOperationStatus_args() {
   }
 
-  virtual ~TCLIService_GetOperationStatus_args() throw() {}
-
+  virtual ~TCLIService_GetOperationStatus_args() throw();
   TGetOperationStatusReq req;
 
   _TCLIService_GetOperationStatus_args__isset __isset;
 
-  void __set_req(const TGetOperationStatusReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetOperationStatusReq& val);
 
   bool operator == (const TCLIService_GetOperationStatus_args & rhs) const
   {
@@ -1346,41 +1480,47 @@ class TCLIService_GetOperationStatus_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetOperationStatus_args& obj);
 };
 
 
 class TCLIService_GetOperationStatus_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
 
-  virtual ~TCLIService_GetOperationStatus_pargs() throw() {}
 
+  virtual ~TCLIService_GetOperationStatus_pargs() throw();
   const TGetOperationStatusReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetOperationStatus_pargs& obj);
 };
 
 typedef struct _TCLIService_GetOperationStatus_result__isset {
   _TCLIService_GetOperationStatus_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetOperationStatus_result__isset;
 
 class TCLIService_GetOperationStatus_result {
  public:
 
+  static const char* ascii_fingerprint; // = "C399947D185D259358E6B922C40ACF85";
+  static const uint8_t binary_fingerprint[16]; // = {0xC3,0x99,0x94,0x7D,0x18,0x5D,0x25,0x93,0x58,0xE6,0xB9,0x22,0xC4,0x0A,0xCF,0x85};
+
+  TCLIService_GetOperationStatus_result(const TCLIService_GetOperationStatus_result&);
+  TCLIService_GetOperationStatus_result& operator=(const TCLIService_GetOperationStatus_result&);
   TCLIService_GetOperationStatus_result() {
   }
 
-  virtual ~TCLIService_GetOperationStatus_result() throw() {}
-
+  virtual ~TCLIService_GetOperationStatus_result() throw();
   TGetOperationStatusResp success;
 
   _TCLIService_GetOperationStatus_result__isset __isset;
 
-  void __set_success(const TGetOperationStatusResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetOperationStatusResp& val);
 
   bool operator == (const TCLIService_GetOperationStatus_result & rhs) const
   {
@@ -1397,47 +1537,53 @@ class TCLIService_GetOperationStatus_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetOperationStatus_result& obj);
 };
 
 typedef struct _TCLIService_GetOperationStatus_presult__isset {
   _TCLIService_GetOperationStatus_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetOperationStatus_presult__isset;
 
 class TCLIService_GetOperationStatus_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "C399947D185D259358E6B922C40ACF85";
+  static const uint8_t binary_fingerprint[16]; // = {0xC3,0x99,0x94,0x7D,0x18,0x5D,0x25,0x93,0x58,0xE6,0xB9,0x22,0xC4,0x0A,0xCF,0x85};
 
-  virtual ~TCLIService_GetOperationStatus_presult() throw() {}
 
+  virtual ~TCLIService_GetOperationStatus_presult() throw();
   TGetOperationStatusResp* success;
 
   _TCLIService_GetOperationStatus_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetOperationStatus_presult& obj);
 };
 
 typedef struct _TCLIService_CancelOperation_args__isset {
   _TCLIService_CancelOperation_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_CancelOperation_args__isset;
 
 class TCLIService_CancelOperation_args {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
+
+  TCLIService_CancelOperation_args(const TCLIService_CancelOperation_args&);
+  TCLIService_CancelOperation_args& operator=(const TCLIService_CancelOperation_args&);
   TCLIService_CancelOperation_args() {
   }
 
-  virtual ~TCLIService_CancelOperation_args() throw() {}
-
+  virtual ~TCLIService_CancelOperation_args() throw();
   TCancelOperationReq req;
 
   _TCLIService_CancelOperation_args__isset __isset;
 
-  void __set_req(const TCancelOperationReq& val) {
-    req = val;
-  }
+  void __set_req(const TCancelOperationReq& val);
 
   bool operator == (const TCLIService_CancelOperation_args & rhs) const
   {
@@ -1454,41 +1600,47 @@ class TCLIService_CancelOperation_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelOperation_args& obj);
 };
 
 
 class TCLIService_CancelOperation_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
 
-  virtual ~TCLIService_CancelOperation_pargs() throw() {}
 
+  virtual ~TCLIService_CancelOperation_pargs() throw();
   const TCancelOperationReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelOperation_pargs& obj);
 };
 
 typedef struct _TCLIService_CancelOperation_result__isset {
   _TCLIService_CancelOperation_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CancelOperation_result__isset;
 
 class TCLIService_CancelOperation_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
+
+  TCLIService_CancelOperation_result(const TCLIService_CancelOperation_result&);
+  TCLIService_CancelOperation_result& operator=(const TCLIService_CancelOperation_result&);
   TCLIService_CancelOperation_result() {
   }
 
-  virtual ~TCLIService_CancelOperation_result() throw() {}
-
+  virtual ~TCLIService_CancelOperation_result() throw();
   TCancelOperationResp success;
 
   _TCLIService_CancelOperation_result__isset __isset;
 
-  void __set_success(const TCancelOperationResp& val) {
-    success = val;
-  }
+  void __set_success(const TCancelOperationResp& val);
 
   bool operator == (const TCLIService_CancelOperation_result & rhs) const
   {
@@ -1505,47 +1657,53 @@ class TCLIService_CancelOperation_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelOperation_result& obj);
 };
 
 typedef struct _TCLIService_CancelOperation_presult__isset {
   _TCLIService_CancelOperation_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CancelOperation_presult__isset;
 
 class TCLIService_CancelOperation_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
 
-  virtual ~TCLIService_CancelOperation_presult() throw() {}
 
+  virtual ~TCLIService_CancelOperation_presult() throw();
   TCancelOperationResp* success;
 
   _TCLIService_CancelOperation_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelOperation_presult& obj);
 };
 
 typedef struct _TCLIService_CloseOperation_args__isset {
   _TCLIService_CloseOperation_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_CloseOperation_args__isset;
 
 class TCLIService_CloseOperation_args {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
+
+  TCLIService_CloseOperation_args(const TCLIService_CloseOperation_args&);
+  TCLIService_CloseOperation_args& operator=(const TCLIService_CloseOperation_args&);
   TCLIService_CloseOperation_args() {
   }
 
-  virtual ~TCLIService_CloseOperation_args() throw() {}
-
+  virtual ~TCLIService_CloseOperation_args() throw();
   TCloseOperationReq req;
 
   _TCLIService_CloseOperation_args__isset __isset;
 
-  void __set_req(const TCloseOperationReq& val) {
-    req = val;
-  }
+  void __set_req(const TCloseOperationReq& val);
 
   bool operator == (const TCLIService_CloseOperation_args & rhs) const
   {
@@ -1562,41 +1720,47 @@ class TCLIService_CloseOperation_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseOperation_args& obj);
 };
 
 
 class TCLIService_CloseOperation_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
 
-  virtual ~TCLIService_CloseOperation_pargs() throw() {}
 
+  virtual ~TCLIService_CloseOperation_pargs() throw();
   const TCloseOperationReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseOperation_pargs& obj);
 };
 
 typedef struct _TCLIService_CloseOperation_result__isset {
   _TCLIService_CloseOperation_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CloseOperation_result__isset;
 
 class TCLIService_CloseOperation_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
+
+  TCLIService_CloseOperation_result(const TCLIService_CloseOperation_result&);
+  TCLIService_CloseOperation_result& operator=(const TCLIService_CloseOperation_result&);
   TCLIService_CloseOperation_result() {
   }
 
-  virtual ~TCLIService_CloseOperation_result() throw() {}
-
+  virtual ~TCLIService_CloseOperation_result() throw();
   TCloseOperationResp success;
 
   _TCLIService_CloseOperation_result__isset __isset;
 
-  void __set_success(const TCloseOperationResp& val) {
-    success = val;
-  }
+  void __set_success(const TCloseOperationResp& val);
 
   bool operator == (const TCLIService_CloseOperation_result & rhs) const
   {
@@ -1613,47 +1777,53 @@ class TCLIService_CloseOperation_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseOperation_result& obj);
 };
 
 typedef struct _TCLIService_CloseOperation_presult__isset {
   _TCLIService_CloseOperation_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CloseOperation_presult__isset;
 
 class TCLIService_CloseOperation_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
 
-  virtual ~TCLIService_CloseOperation_presult() throw() {}
 
+  virtual ~TCLIService_CloseOperation_presult() throw();
   TCloseOperationResp* success;
 
   _TCLIService_CloseOperation_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CloseOperation_presult& obj);
 };
 
 typedef struct _TCLIService_GetResultSetMetadata_args__isset {
   _TCLIService_GetResultSetMetadata_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetResultSetMetadata_args__isset;
 
 class TCLIService_GetResultSetMetadata_args {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
+
+  TCLIService_GetResultSetMetadata_args(const TCLIService_GetResultSetMetadata_args&);
+  TCLIService_GetResultSetMetadata_args& operator=(const TCLIService_GetResultSetMetadata_args&);
   TCLIService_GetResultSetMetadata_args() {
   }
 
-  virtual ~TCLIService_GetResultSetMetadata_args() throw() {}
-
+  virtual ~TCLIService_GetResultSetMetadata_args() throw();
   TGetResultSetMetadataReq req;
 
   _TCLIService_GetResultSetMetadata_args__isset __isset;
 
-  void __set_req(const TGetResultSetMetadataReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetResultSetMetadataReq& val);
 
   bool operator == (const TCLIService_GetResultSetMetadata_args & rhs) const
   {
@@ -1670,41 +1840,47 @@ class TCLIService_GetResultSetMetadata_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetResultSetMetadata_args& obj);
 };
 
 
 class TCLIService_GetResultSetMetadata_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "2A0009415DC2A8A9CDCF3A75C16ADBE7";
+  static const uint8_t binary_fingerprint[16]; // = {0x2A,0x00,0x09,0x41,0x5D,0xC2,0xA8,0xA9,0xCD,0xCF,0x3A,0x75,0xC1,0x6A,0xDB,0xE7};
 
-  virtual ~TCLIService_GetResultSetMetadata_pargs() throw() {}
 
+  virtual ~TCLIService_GetResultSetMetadata_pargs() throw();
   const TGetResultSetMetadataReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetResultSetMetadata_pargs& obj);
 };
 
 typedef struct _TCLIService_GetResultSetMetadata_result__isset {
   _TCLIService_GetResultSetMetadata_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetResultSetMetadata_result__isset;
 
 class TCLIService_GetResultSetMetadata_result {
  public:
 
+  static const char* ascii_fingerprint; // = "748CA3BE2055D5C1AD7EAAEF01F7C463";
+  static const uint8_t binary_fingerprint[16]; // = {0x74,0x8C,0xA3,0xBE,0x20,0x55,0xD5,0xC1,0xAD,0x7E,0xAA,0xEF,0x01,0xF7,0xC4,0x63};
+
+  TCLIService_GetResultSetMetadata_result(const TCLIService_GetResultSetMetadata_result&);
+  TCLIService_GetResultSetMetadata_result& operator=(const TCLIService_GetResultSetMetadata_result&);
   TCLIService_GetResultSetMetadata_result() {
   }
 
-  virtual ~TCLIService_GetResultSetMetadata_result() throw() {}
-
+  virtual ~TCLIService_GetResultSetMetadata_result() throw();
   TGetResultSetMetadataResp success;
 
   _TCLIService_GetResultSetMetadata_result__isset __isset;
 
-  void __set_success(const TGetResultSetMetadataResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetResultSetMetadataResp& val);
 
   bool operator == (const TCLIService_GetResultSetMetadata_result & rhs) const
   {
@@ -1721,47 +1897,53 @@ class TCLIService_GetResultSetMetadata_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetResultSetMetadata_result& obj);
 };
 
 typedef struct _TCLIService_GetResultSetMetadata_presult__isset {
   _TCLIService_GetResultSetMetadata_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetResultSetMetadata_presult__isset;
 
 class TCLIService_GetResultSetMetadata_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "748CA3BE2055D5C1AD7EAAEF01F7C463";
+  static const uint8_t binary_fingerprint[16]; // = {0x74,0x8C,0xA3,0xBE,0x20,0x55,0xD5,0xC1,0xAD,0x7E,0xAA,0xEF,0x01,0xF7,0xC4,0x63};
 
-  virtual ~TCLIService_GetResultSetMetadata_presult() throw() {}
 
+  virtual ~TCLIService_GetResultSetMetadata_presult() throw();
   TGetResultSetMetadataResp* success;
 
   _TCLIService_GetResultSetMetadata_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetResultSetMetadata_presult& obj);
 };
 
 typedef struct _TCLIService_FetchResults_args__isset {
   _TCLIService_FetchResults_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_FetchResults_args__isset;
 
 class TCLIService_FetchResults_args {
  public:
 
+  static const char* ascii_fingerprint; // = "9861C5443566158A1DAEAC80886635C8";
+  static const uint8_t binary_fingerprint[16]; // = {0x98,0x61,0xC5,0x44,0x35,0x66,0x15,0x8A,0x1D,0xAE,0xAC,0x80,0x88,0x66,0x35,0xC8};
+
+  TCLIService_FetchResults_args(const TCLIService_FetchResults_args&);
+  TCLIService_FetchResults_args& operator=(const TCLIService_FetchResults_args&);
   TCLIService_FetchResults_args() {
   }
 
-  virtual ~TCLIService_FetchResults_args() throw() {}
-
+  virtual ~TCLIService_FetchResults_args() throw();
   TFetchResultsReq req;
 
   _TCLIService_FetchResults_args__isset __isset;
 
-  void __set_req(const TFetchResultsReq& val) {
-    req = val;
-  }
+  void __set_req(const TFetchResultsReq& val);
 
   bool operator == (const TCLIService_FetchResults_args & rhs) const
   {
@@ -1778,41 +1960,47 @@ class TCLIService_FetchResults_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_FetchResults_args& obj);
 };
 
 
 class TCLIService_FetchResults_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "9861C5443566158A1DAEAC80886635C8";
+  static const uint8_t binary_fingerprint[16]; // = {0x98,0x61,0xC5,0x44,0x35,0x66,0x15,0x8A,0x1D,0xAE,0xAC,0x80,0x88,0x66,0x35,0xC8};
 
-  virtual ~TCLIService_FetchResults_pargs() throw() {}
 
+  virtual ~TCLIService_FetchResults_pargs() throw();
   const TFetchResultsReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_FetchResults_pargs& obj);
 };
 
 typedef struct _TCLIService_FetchResults_result__isset {
   _TCLIService_FetchResults_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_FetchResults_result__isset;
 
 class TCLIService_FetchResults_result {
  public:
 
+  static const char* ascii_fingerprint; // = "CDEF797B9FFCA6B2CD18163A3D78F196";
+  static const uint8_t binary_fingerprint[16]; // = {0xCD,0xEF,0x79,0x7B,0x9F,0xFC,0xA6,0xB2,0xCD,0x18,0x16,0x3A,0x3D,0x78,0xF1,0x96};
+
+  TCLIService_FetchResults_result(const TCLIService_FetchResults_result&);
+  TCLIService_FetchResults_result& operator=(const TCLIService_FetchResults_result&);
   TCLIService_FetchResults_result() {
   }
 
-  virtual ~TCLIService_FetchResults_result() throw() {}
-
+  virtual ~TCLIService_FetchResults_result() throw();
   TFetchResultsResp success;
 
   _TCLIService_FetchResults_result__isset __isset;
 
-  void __set_success(const TFetchResultsResp& val) {
-    success = val;
-  }
+  void __set_success(const TFetchResultsResp& val);
 
   bool operator == (const TCLIService_FetchResults_result & rhs) const
   {
@@ -1829,47 +2017,53 @@ class TCLIService_FetchResults_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_FetchResults_result& obj);
 };
 
 typedef struct _TCLIService_FetchResults_presult__isset {
   _TCLIService_FetchResults_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_FetchResults_presult__isset;
 
 class TCLIService_FetchResults_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "CDEF797B9FFCA6B2CD18163A3D78F196";
+  static const uint8_t binary_fingerprint[16]; // = {0xCD,0xEF,0x79,0x7B,0x9F,0xFC,0xA6,0xB2,0xCD,0x18,0x16,0x3A,0x3D,0x78,0xF1,0x96};
 
-  virtual ~TCLIService_FetchResults_presult() throw() {}
 
+  virtual ~TCLIService_FetchResults_presult() throw();
   TFetchResultsResp* success;
 
   _TCLIService_FetchResults_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_FetchResults_presult& obj);
 };
 
 typedef struct _TCLIService_GetDelegationToken_args__isset {
   _TCLIService_GetDelegationToken_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_GetDelegationToken_args__isset;
 
 class TCLIService_GetDelegationToken_args {
  public:
 
+  static const char* ascii_fingerprint; // = "BF8EEEB8C67FB6195D3D9BA5BA2C58A4";
+  static const uint8_t binary_fingerprint[16]; // = {0xBF,0x8E,0xEE,0xB8,0xC6,0x7F,0xB6,0x19,0x5D,0x3D,0x9B,0xA5,0xBA,0x2C,0x58,0xA4};
+
+  TCLIService_GetDelegationToken_args(const TCLIService_GetDelegationToken_args&);
+  TCLIService_GetDelegationToken_args& operator=(const TCLIService_GetDelegationToken_args&);
   TCLIService_GetDelegationToken_args() {
   }
 
-  virtual ~TCLIService_GetDelegationToken_args() throw() {}
-
+  virtual ~TCLIService_GetDelegationToken_args() throw();
   TGetDelegationTokenReq req;
 
   _TCLIService_GetDelegationToken_args__isset __isset;
 
-  void __set_req(const TGetDelegationTokenReq& val) {
-    req = val;
-  }
+  void __set_req(const TGetDelegationTokenReq& val);
 
   bool operator == (const TCLIService_GetDelegationToken_args & rhs) const
   {
@@ -1886,41 +2080,47 @@ class TCLIService_GetDelegationToken_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetDelegationToken_args& obj);
 };
 
 
 class TCLIService_GetDelegationToken_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "BF8EEEB8C67FB6195D3D9BA5BA2C58A4";
+  static const uint8_t binary_fingerprint[16]; // = {0xBF,0x8E,0xEE,0xB8,0xC6,0x7F,0xB6,0x19,0x5D,0x3D,0x9B,0xA5,0xBA,0x2C,0x58,0xA4};
 
-  virtual ~TCLIService_GetDelegationToken_pargs() throw() {}
 
+  virtual ~TCLIService_GetDelegationToken_pargs() throw();
   const TGetDelegationTokenReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetDelegationToken_pargs& obj);
 };
 
 typedef struct _TCLIService_GetDelegationToken_result__isset {
   _TCLIService_GetDelegationToken_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetDelegationToken_result__isset;
 
 class TCLIService_GetDelegationToken_result {
  public:
 
+  static const char* ascii_fingerprint; // = "58C1B84BE91071117FFEBB0AFA1636F7";
+  static const uint8_t binary_fingerprint[16]; // = {0x58,0xC1,0xB8,0x4B,0xE9,0x10,0x71,0x11,0x7F,0xFE,0xBB,0x0A,0xFA,0x16,0x36,0xF7};
+
+  TCLIService_GetDelegationToken_result(const TCLIService_GetDelegationToken_result&);
+  TCLIService_GetDelegationToken_result& operator=(const TCLIService_GetDelegationToken_result&);
   TCLIService_GetDelegationToken_result() {
   }
 
-  virtual ~TCLIService_GetDelegationToken_result() throw() {}
-
+  virtual ~TCLIService_GetDelegationToken_result() throw();
   TGetDelegationTokenResp success;
 
   _TCLIService_GetDelegationToken_result__isset __isset;
 
-  void __set_success(const TGetDelegationTokenResp& val) {
-    success = val;
-  }
+  void __set_success(const TGetDelegationTokenResp& val);
 
   bool operator == (const TCLIService_GetDelegationToken_result & rhs) const
   {
@@ -1937,47 +2137,53 @@ class TCLIService_GetDelegationToken_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetDelegationToken_result& obj);
 };
 
 typedef struct _TCLIService_GetDelegationToken_presult__isset {
   _TCLIService_GetDelegationToken_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_GetDelegationToken_presult__isset;
 
 class TCLIService_GetDelegationToken_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "58C1B84BE91071117FFEBB0AFA1636F7";
+  static const uint8_t binary_fingerprint[16]; // = {0x58,0xC1,0xB8,0x4B,0xE9,0x10,0x71,0x11,0x7F,0xFE,0xBB,0x0A,0xFA,0x16,0x36,0xF7};
 
-  virtual ~TCLIService_GetDelegationToken_presult() throw() {}
 
+  virtual ~TCLIService_GetDelegationToken_presult() throw();
   TGetDelegationTokenResp* success;
 
   _TCLIService_GetDelegationToken_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_GetDelegationToken_presult& obj);
 };
 
 typedef struct _TCLIService_CancelDelegationToken_args__isset {
   _TCLIService_CancelDelegationToken_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_CancelDelegationToken_args__isset;
 
 class TCLIService_CancelDelegationToken_args {
  public:
 
+  static const char* ascii_fingerprint; // = "9C6A93D9444D84C6B888C2DA30E4CB54";
+  static const uint8_t binary_fingerprint[16]; // = {0x9C,0x6A,0x93,0xD9,0x44,0x4D,0x84,0xC6,0xB8,0x88,0xC2,0xDA,0x30,0xE4,0xCB,0x54};
+
+  TCLIService_CancelDelegationToken_args(const TCLIService_CancelDelegationToken_args&);
+  TCLIService_CancelDelegationToken_args& operator=(const TCLIService_CancelDelegationToken_args&);
   TCLIService_CancelDelegationToken_args() {
   }
 
-  virtual ~TCLIService_CancelDelegationToken_args() throw() {}
-
+  virtual ~TCLIService_CancelDelegationToken_args() throw();
   TCancelDelegationTokenReq req;
 
   _TCLIService_CancelDelegationToken_args__isset __isset;
 
-  void __set_req(const TCancelDelegationTokenReq& val) {
-    req = val;
-  }
+  void __set_req(const TCancelDelegationTokenReq& val);
 
   bool operator == (const TCLIService_CancelDelegationToken_args & rhs) const
   {
@@ -1994,41 +2200,47 @@ class TCLIService_CancelDelegationToken_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelDelegationToken_args& obj);
 };
 
 
 class TCLIService_CancelDelegationToken_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "9C6A93D9444D84C6B888C2DA30E4CB54";
+  static const uint8_t binary_fingerprint[16]; // = {0x9C,0x6A,0x93,0xD9,0x44,0x4D,0x84,0xC6,0xB8,0x88,0xC2,0xDA,0x30,0xE4,0xCB,0x54};
 
-  virtual ~TCLIService_CancelDelegationToken_pargs() throw() {}
 
+  virtual ~TCLIService_CancelDelegationToken_pargs() throw();
   const TCancelDelegationTokenReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelDelegationToken_pargs& obj);
 };
 
 typedef struct _TCLIService_CancelDelegationToken_result__isset {
   _TCLIService_CancelDelegationToken_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CancelDelegationToken_result__isset;
 
 class TCLIService_CancelDelegationToken_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
+
+  TCLIService_CancelDelegationToken_result(const TCLIService_CancelDelegationToken_result&);
+  TCLIService_CancelDelegationToken_result& operator=(const TCLIService_CancelDelegationToken_result&);
   TCLIService_CancelDelegationToken_result() {
   }
 
-  virtual ~TCLIService_CancelDelegationToken_result() throw() {}
-
+  virtual ~TCLIService_CancelDelegationToken_result() throw();
   TCancelDelegationTokenResp success;
 
   _TCLIService_CancelDelegationToken_result__isset __isset;
 
-  void __set_success(const TCancelDelegationTokenResp& val) {
-    success = val;
-  }
+  void __set_success(const TCancelDelegationTokenResp& val);
 
   bool operator == (const TCLIService_CancelDelegationToken_result & rhs) const
   {
@@ -2045,47 +2257,53 @@ class TCLIService_CancelDelegationToken_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelDelegationToken_result& obj);
 };
 
 typedef struct _TCLIService_CancelDelegationToken_presult__isset {
   _TCLIService_CancelDelegationToken_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_CancelDelegationToken_presult__isset;
 
 class TCLIService_CancelDelegationToken_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
 
-  virtual ~TCLIService_CancelDelegationToken_presult() throw() {}
 
+  virtual ~TCLIService_CancelDelegationToken_presult() throw();
   TCancelDelegationTokenResp* success;
 
   _TCLIService_CancelDelegationToken_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_CancelDelegationToken_presult& obj);
 };
 
 typedef struct _TCLIService_RenewDelegationToken_args__isset {
   _TCLIService_RenewDelegationToken_args__isset() : req(false) {}
-  bool req;
+  bool req :1;
 } _TCLIService_RenewDelegationToken_args__isset;
 
 class TCLIService_RenewDelegationToken_args {
  public:
 
+  static const char* ascii_fingerprint; // = "9C6A93D9444D84C6B888C2DA30E4CB54";
+  static const uint8_t binary_fingerprint[16]; // = {0x9C,0x6A,0x93,0xD9,0x44,0x4D,0x84,0xC6,0xB8,0x88,0xC2,0xDA,0x30,0xE4,0xCB,0x54};
+
+  TCLIService_RenewDelegationToken_args(const TCLIService_RenewDelegationToken_args&);
+  TCLIService_RenewDelegationToken_args& operator=(const TCLIService_RenewDelegationToken_args&);
   TCLIService_RenewDelegationToken_args() {
   }
 
-  virtual ~TCLIService_RenewDelegationToken_args() throw() {}
-
+  virtual ~TCLIService_RenewDelegationToken_args() throw();
   TRenewDelegationTokenReq req;
 
   _TCLIService_RenewDelegationToken_args__isset __isset;
 
-  void __set_req(const TRenewDelegationTokenReq& val) {
-    req = val;
-  }
+  void __set_req(const TRenewDelegationTokenReq& val);
 
   bool operator == (const TCLIService_RenewDelegationToken_args & rhs) const
   {
@@ -2102,41 +2320,47 @@ class TCLIService_RenewDelegationToken_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_RenewDelegationToken_args& obj);
 };
 
 
 class TCLIService_RenewDelegationToken_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "9C6A93D9444D84C6B888C2DA30E4CB54";
+  static const uint8_t binary_fingerprint[16]; // = {0x9C,0x6A,0x93,0xD9,0x44,0x4D,0x84,0xC6,0xB8,0x88,0xC2,0xDA,0x30,0xE4,0xCB,0x54};
 
-  virtual ~TCLIService_RenewDelegationToken_pargs() throw() {}
 
+  virtual ~TCLIService_RenewDelegationToken_pargs() throw();
   const TRenewDelegationTokenReq* req;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_RenewDelegationToken_pargs& obj);
 };
 
 typedef struct _TCLIService_RenewDelegationToken_result__isset {
   _TCLIService_RenewDelegationToken_result__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_RenewDelegationToken_result__isset;
 
 class TCLIService_RenewDelegationToken_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
+
+  TCLIService_RenewDelegationToken_result(const TCLIService_RenewDelegationToken_result&);
+  TCLIService_RenewDelegationToken_result& operator=(const TCLIService_RenewDelegationToken_result&);
   TCLIService_RenewDelegationToken_result() {
   }
 
-  virtual ~TCLIService_RenewDelegationToken_result() throw() {}
-
+  virtual ~TCLIService_RenewDelegationToken_result() throw();
   TRenewDelegationTokenResp success;
 
   _TCLIService_RenewDelegationToken_result__isset __isset;
 
-  void __set_success(const TRenewDelegationTokenResp& val) {
-    success = val;
-  }
+  void __set_success(const TRenewDelegationTokenResp& val);
 
   bool operator == (const TCLIService_RenewDelegationToken_result & rhs) const
   {
@@ -2153,41 +2377,50 @@ class TCLIService_RenewDelegationToken_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_RenewDelegationToken_result& obj);
 };
 
 typedef struct _TCLIService_RenewDelegationToken_presult__isset {
   _TCLIService_RenewDelegationToken_presult__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _TCLIService_RenewDelegationToken_presult__isset;
 
 class TCLIService_RenewDelegationToken_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BDB51A479DCD1EB1DB636FA1B4BE02A7";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0xB5,0x1A,0x47,0x9D,0xCD,0x1E,0xB1,0xDB,0x63,0x6F,0xA1,0xB4,0xBE,0x02,0xA7};
 
-  virtual ~TCLIService_RenewDelegationToken_presult() throw() {}
 
+  virtual ~TCLIService_RenewDelegationToken_presult() throw();
   TRenewDelegationTokenResp* success;
 
   _TCLIService_RenewDelegationToken_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const TCLIService_RenewDelegationToken_presult& obj);
 };
 
 class TCLIServiceClient : virtual public TCLIServiceIf {
  public:
-  TCLIServiceClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> prot) :
-    piprot_(prot),
-    poprot_(prot) {
-    iprot_ = prot.get();
-    oprot_ = prot.get();
+  TCLIServiceClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> prot) {
+    setProtocol(prot);
+  }
+  TCLIServiceClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr< ::apache::thrift::protocol::TProtocol> oprot) {
+    setProtocol(iprot,oprot);
   }
-  TCLIServiceClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr< ::apache::thrift::protocol::TProtocol> oprot) :
-    piprot_(iprot),
-    poprot_(oprot) {
+ private:
+  void setProtocol(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> prot) {
+  setProtocol(prot,prot);
+  }
+  void setProtocol(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr< ::apache::thrift::protocol::TProtocol> oprot) {
+    piprot_=iprot;
+    poprot_=oprot;
     iprot_ = iprot.get();
     oprot_ = oprot.get();
   }
+ public:
   boost::shared_ptr< ::apache::thrift::protocol::TProtocol> getInputProtocol() {
     return piprot_;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService_constants.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService_constants.cpp b/service/src/gen/thrift/gen-cpp/TCLIService_constants.cpp
index d1551b5..dcca5c8 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService_constants.cpp
+++ b/service/src/gen/thrift/gen-cpp/TCLIService_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService_constants.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService_constants.h b/service/src/gen/thrift/gen-cpp/TCLIService_constants.h
index e5a7a1f..8993394 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService_constants.h
+++ b/service/src/gen/thrift/gen-cpp/TCLIService_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[11/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/ThriftHive.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/ThriftHive.cpp b/service/src/gen/thrift/gen-cpp/ThriftHive.cpp
index 865db69..8935c04 100644
--- a/service/src/gen/thrift/gen-cpp/ThriftHive.cpp
+++ b/service/src/gen/thrift/gen-cpp/ThriftHive.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -8,6 +8,11 @@
 
 namespace Apache { namespace Hadoop { namespace Hive {
 
+
+ThriftHive_execute_args::~ThriftHive_execute_args() throw() {
+}
+
+
 uint32_t ThriftHive_execute_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -50,6 +55,7 @@ uint32_t ThriftHive_execute_args::read(::apache::thrift::protocol::TProtocol* ip
 
 uint32_t ThriftHive_execute_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_execute_args");
 
   xfer += oprot->writeFieldBegin("query", ::apache::thrift::protocol::T_STRING, 1);
@@ -58,11 +64,18 @@ uint32_t ThriftHive_execute_args::write(::apache::thrift::protocol::TProtocol* o
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_execute_pargs::~ThriftHive_execute_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_execute_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_execute_pargs");
 
   xfer += oprot->writeFieldBegin("query", ::apache::thrift::protocol::T_STRING, 1);
@@ -71,9 +84,15 @@ uint32_t ThriftHive_execute_pargs::write(::apache::thrift::protocol::TProtocol*
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_execute_result::~ThriftHive_execute_result() throw() {
+}
+
+
 uint32_t ThriftHive_execute_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -130,6 +149,11 @@ uint32_t ThriftHive_execute_result::write(::apache::thrift::protocol::TProtocol*
   return xfer;
 }
 
+
+ThriftHive_execute_presult::~ThriftHive_execute_presult() throw() {
+}
+
+
 uint32_t ThriftHive_execute_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -170,6 +194,11 @@ uint32_t ThriftHive_execute_presult::read(::apache::thrift::protocol::TProtocol*
   return xfer;
 }
 
+
+ThriftHive_fetchOne_args::~ThriftHive_fetchOne_args() throw() {
+}
+
+
 uint32_t ThriftHive_fetchOne_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -199,22 +228,36 @@ uint32_t ThriftHive_fetchOne_args::read(::apache::thrift::protocol::TProtocol* i
 
 uint32_t ThriftHive_fetchOne_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchOne_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchOne_pargs::~ThriftHive_fetchOne_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_fetchOne_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchOne_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchOne_result::~ThriftHive_fetchOne_result() throw() {
+}
+
+
 uint32_t ThriftHive_fetchOne_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -283,6 +326,11 @@ uint32_t ThriftHive_fetchOne_result::write(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+ThriftHive_fetchOne_presult::~ThriftHive_fetchOne_presult() throw() {
+}
+
+
 uint32_t ThriftHive_fetchOne_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -331,6 +379,11 @@ uint32_t ThriftHive_fetchOne_presult::read(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+ThriftHive_fetchN_args::~ThriftHive_fetchN_args() throw() {
+}
+
+
 uint32_t ThriftHive_fetchN_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -373,6 +426,7 @@ uint32_t ThriftHive_fetchN_args::read(::apache::thrift::protocol::TProtocol* ipr
 
 uint32_t ThriftHive_fetchN_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchN_args");
 
   xfer += oprot->writeFieldBegin("numRows", ::apache::thrift::protocol::T_I32, 1);
@@ -381,11 +435,18 @@ uint32_t ThriftHive_fetchN_args::write(::apache::thrift::protocol::TProtocol* op
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchN_pargs::~ThriftHive_fetchN_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_fetchN_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchN_pargs");
 
   xfer += oprot->writeFieldBegin("numRows", ::apache::thrift::protocol::T_I32, 1);
@@ -394,9 +455,15 @@ uint32_t ThriftHive_fetchN_pargs::write(::apache::thrift::protocol::TProtocol* o
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchN_result::~ThriftHive_fetchN_result() throw() {
+}
+
+
 uint32_t ThriftHive_fetchN_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -421,14 +488,14 @@ uint32_t ThriftHive_fetchN_result::read(::apache::thrift::protocol::TProtocol* i
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size1;
-            ::apache::thrift::protocol::TType _etype4;
-            xfer += iprot->readListBegin(_etype4, _size1);
-            this->success.resize(_size1);
-            uint32_t _i5;
-            for (_i5 = 0; _i5 < _size1; ++_i5)
+            uint32_t _size5;
+            ::apache::thrift::protocol::TType _etype8;
+            xfer += iprot->readListBegin(_etype8, _size5);
+            this->success.resize(_size5);
+            uint32_t _i9;
+            for (_i9 = 0; _i9 < _size5; ++_i9)
             {
-              xfer += iprot->readString(this->success[_i5]);
+              xfer += iprot->readString(this->success[_i9]);
             }
             xfer += iprot->readListEnd();
           }
@@ -467,10 +534,10 @@ uint32_t ThriftHive_fetchN_result::write(::apache::thrift::protocol::TProtocol*
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter6;
-      for (_iter6 = this->success.begin(); _iter6 != this->success.end(); ++_iter6)
+      std::vector<std::string> ::const_iterator _iter10;
+      for (_iter10 = this->success.begin(); _iter10 != this->success.end(); ++_iter10)
       {
-        xfer += oprot->writeString((*_iter6));
+        xfer += oprot->writeString((*_iter10));
       }
       xfer += oprot->writeListEnd();
     }
@@ -485,6 +552,11 @@ uint32_t ThriftHive_fetchN_result::write(::apache::thrift::protocol::TProtocol*
   return xfer;
 }
 
+
+ThriftHive_fetchN_presult::~ThriftHive_fetchN_presult() throw() {
+}
+
+
 uint32_t ThriftHive_fetchN_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -509,14 +581,14 @@ uint32_t ThriftHive_fetchN_presult::read(::apache::thrift::protocol::TProtocol*
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size7;
-            ::apache::thrift::protocol::TType _etype10;
-            xfer += iprot->readListBegin(_etype10, _size7);
-            (*(this->success)).resize(_size7);
-            uint32_t _i11;
-            for (_i11 = 0; _i11 < _size7; ++_i11)
+            uint32_t _size11;
+            ::apache::thrift::protocol::TType _etype14;
+            xfer += iprot->readListBegin(_etype14, _size11);
+            (*(this->success)).resize(_size11);
+            uint32_t _i15;
+            for (_i15 = 0; _i15 < _size11; ++_i15)
             {
-              xfer += iprot->readString((*(this->success))[_i11]);
+              xfer += iprot->readString((*(this->success))[_i15]);
             }
             xfer += iprot->readListEnd();
           }
@@ -545,6 +617,11 @@ uint32_t ThriftHive_fetchN_presult::read(::apache::thrift::protocol::TProtocol*
   return xfer;
 }
 
+
+ThriftHive_fetchAll_args::~ThriftHive_fetchAll_args() throw() {
+}
+
+
 uint32_t ThriftHive_fetchAll_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -574,22 +651,36 @@ uint32_t ThriftHive_fetchAll_args::read(::apache::thrift::protocol::TProtocol* i
 
 uint32_t ThriftHive_fetchAll_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchAll_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchAll_pargs::~ThriftHive_fetchAll_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_fetchAll_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_fetchAll_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_fetchAll_result::~ThriftHive_fetchAll_result() throw() {
+}
+
+
 uint32_t ThriftHive_fetchAll_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -614,14 +705,14 @@ uint32_t ThriftHive_fetchAll_result::read(::apache::thrift::protocol::TProtocol*
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->success.clear();
-            uint32_t _size12;
-            ::apache::thrift::protocol::TType _etype15;
-            xfer += iprot->readListBegin(_etype15, _size12);
-            this->success.resize(_size12);
-            uint32_t _i16;
-            for (_i16 = 0; _i16 < _size12; ++_i16)
+            uint32_t _size16;
+            ::apache::thrift::protocol::TType _etype19;
+            xfer += iprot->readListBegin(_etype19, _size16);
+            this->success.resize(_size16);
+            uint32_t _i20;
+            for (_i20 = 0; _i20 < _size16; ++_i20)
             {
-              xfer += iprot->readString(this->success[_i16]);
+              xfer += iprot->readString(this->success[_i20]);
             }
             xfer += iprot->readListEnd();
           }
@@ -660,10 +751,10 @@ uint32_t ThriftHive_fetchAll_result::write(::apache::thrift::protocol::TProtocol
     xfer += oprot->writeFieldBegin("success", ::apache::thrift::protocol::T_LIST, 0);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->success.size()));
-      std::vector<std::string> ::const_iterator _iter17;
-      for (_iter17 = this->success.begin(); _iter17 != this->success.end(); ++_iter17)
+      std::vector<std::string> ::const_iterator _iter21;
+      for (_iter21 = this->success.begin(); _iter21 != this->success.end(); ++_iter21)
       {
-        xfer += oprot->writeString((*_iter17));
+        xfer += oprot->writeString((*_iter21));
       }
       xfer += oprot->writeListEnd();
     }
@@ -678,6 +769,11 @@ uint32_t ThriftHive_fetchAll_result::write(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+ThriftHive_fetchAll_presult::~ThriftHive_fetchAll_presult() throw() {
+}
+
+
 uint32_t ThriftHive_fetchAll_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -702,14 +798,14 @@ uint32_t ThriftHive_fetchAll_presult::read(::apache::thrift::protocol::TProtocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             (*(this->success)).clear();
-            uint32_t _size18;
-            ::apache::thrift::protocol::TType _etype21;
-            xfer += iprot->readListBegin(_etype21, _size18);
-            (*(this->success)).resize(_size18);
-            uint32_t _i22;
-            for (_i22 = 0; _i22 < _size18; ++_i22)
+            uint32_t _size22;
+            ::apache::thrift::protocol::TType _etype25;
+            xfer += iprot->readListBegin(_etype25, _size22);
+            (*(this->success)).resize(_size22);
+            uint32_t _i26;
+            for (_i26 = 0; _i26 < _size22; ++_i26)
             {
-              xfer += iprot->readString((*(this->success))[_i22]);
+              xfer += iprot->readString((*(this->success))[_i26]);
             }
             xfer += iprot->readListEnd();
           }
@@ -738,6 +834,11 @@ uint32_t ThriftHive_fetchAll_presult::read(::apache::thrift::protocol::TProtocol
   return xfer;
 }
 
+
+ThriftHive_getSchema_args::~ThriftHive_getSchema_args() throw() {
+}
+
+
 uint32_t ThriftHive_getSchema_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -767,22 +868,36 @@ uint32_t ThriftHive_getSchema_args::read(::apache::thrift::protocol::TProtocol*
 
 uint32_t ThriftHive_getSchema_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getSchema_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getSchema_pargs::~ThriftHive_getSchema_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_getSchema_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getSchema_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getSchema_result::~ThriftHive_getSchema_result() throw() {
+}
+
+
 uint32_t ThriftHive_getSchema_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -851,6 +966,11 @@ uint32_t ThriftHive_getSchema_result::write(::apache::thrift::protocol::TProtoco
   return xfer;
 }
 
+
+ThriftHive_getSchema_presult::~ThriftHive_getSchema_presult() throw() {
+}
+
+
 uint32_t ThriftHive_getSchema_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -899,6 +1019,11 @@ uint32_t ThriftHive_getSchema_presult::read(::apache::thrift::protocol::TProtoco
   return xfer;
 }
 
+
+ThriftHive_getThriftSchema_args::~ThriftHive_getThriftSchema_args() throw() {
+}
+
+
 uint32_t ThriftHive_getThriftSchema_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -928,22 +1053,36 @@ uint32_t ThriftHive_getThriftSchema_args::read(::apache::thrift::protocol::TProt
 
 uint32_t ThriftHive_getThriftSchema_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getThriftSchema_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getThriftSchema_pargs::~ThriftHive_getThriftSchema_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_getThriftSchema_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getThriftSchema_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getThriftSchema_result::~ThriftHive_getThriftSchema_result() throw() {
+}
+
+
 uint32_t ThriftHive_getThriftSchema_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1012,6 +1151,11 @@ uint32_t ThriftHive_getThriftSchema_result::write(::apache::thrift::protocol::TP
   return xfer;
 }
 
+
+ThriftHive_getThriftSchema_presult::~ThriftHive_getThriftSchema_presult() throw() {
+}
+
+
 uint32_t ThriftHive_getThriftSchema_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1060,6 +1204,11 @@ uint32_t ThriftHive_getThriftSchema_presult::read(::apache::thrift::protocol::TP
   return xfer;
 }
 
+
+ThriftHive_getClusterStatus_args::~ThriftHive_getClusterStatus_args() throw() {
+}
+
+
 uint32_t ThriftHive_getClusterStatus_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1089,22 +1238,36 @@ uint32_t ThriftHive_getClusterStatus_args::read(::apache::thrift::protocol::TPro
 
 uint32_t ThriftHive_getClusterStatus_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getClusterStatus_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getClusterStatus_pargs::~ThriftHive_getClusterStatus_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_getClusterStatus_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getClusterStatus_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getClusterStatus_result::~ThriftHive_getClusterStatus_result() throw() {
+}
+
+
 uint32_t ThriftHive_getClusterStatus_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1173,6 +1336,11 @@ uint32_t ThriftHive_getClusterStatus_result::write(::apache::thrift::protocol::T
   return xfer;
 }
 
+
+ThriftHive_getClusterStatus_presult::~ThriftHive_getClusterStatus_presult() throw() {
+}
+
+
 uint32_t ThriftHive_getClusterStatus_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1221,6 +1389,11 @@ uint32_t ThriftHive_getClusterStatus_presult::read(::apache::thrift::protocol::T
   return xfer;
 }
 
+
+ThriftHive_getQueryPlan_args::~ThriftHive_getQueryPlan_args() throw() {
+}
+
+
 uint32_t ThriftHive_getQueryPlan_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1250,22 +1423,36 @@ uint32_t ThriftHive_getQueryPlan_args::read(::apache::thrift::protocol::TProtoco
 
 uint32_t ThriftHive_getQueryPlan_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getQueryPlan_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getQueryPlan_pargs::~ThriftHive_getQueryPlan_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_getQueryPlan_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_getQueryPlan_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_getQueryPlan_result::~ThriftHive_getQueryPlan_result() throw() {
+}
+
+
 uint32_t ThriftHive_getQueryPlan_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1334,6 +1521,11 @@ uint32_t ThriftHive_getQueryPlan_result::write(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+ThriftHive_getQueryPlan_presult::~ThriftHive_getQueryPlan_presult() throw() {
+}
+
+
 uint32_t ThriftHive_getQueryPlan_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1382,6 +1574,11 @@ uint32_t ThriftHive_getQueryPlan_presult::read(::apache::thrift::protocol::TProt
   return xfer;
 }
 
+
+ThriftHive_clean_args::~ThriftHive_clean_args() throw() {
+}
+
+
 uint32_t ThriftHive_clean_args::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1411,22 +1608,36 @@ uint32_t ThriftHive_clean_args::read(::apache::thrift::protocol::TProtocol* ipro
 
 uint32_t ThriftHive_clean_args::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_clean_args");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_clean_pargs::~ThriftHive_clean_pargs() throw() {
+}
+
+
 uint32_t ThriftHive_clean_pargs::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("ThriftHive_clean_pargs");
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
+
+ThriftHive_clean_result::~ThriftHive_clean_result() throw() {
+}
+
+
 uint32_t ThriftHive_clean_result::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;
@@ -1465,6 +1676,11 @@ uint32_t ThriftHive_clean_result::write(::apache::thrift::protocol::TProtocol* o
   return xfer;
 }
 
+
+ThriftHive_clean_presult::~ThriftHive_clean_presult() throw() {
+}
+
+
 uint32_t ThriftHive_clean_presult::read(::apache::thrift::protocol::TProtocol* iprot) {
 
   uint32_t xfer = 0;

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/ThriftHive.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/ThriftHive.h b/service/src/gen/thrift/gen-cpp/ThriftHive.h
index b84362b..e610e50 100644
--- a/service/src/gen/thrift/gen-cpp/ThriftHive.h
+++ b/service/src/gen/thrift/gen-cpp/ThriftHive.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -85,24 +85,26 @@ class ThriftHiveNull : virtual public ThriftHiveIf , virtual public  ::Apache::H
 
 typedef struct _ThriftHive_execute_args__isset {
   _ThriftHive_execute_args__isset() : query(false) {}
-  bool query;
+  bool query :1;
 } _ThriftHive_execute_args__isset;
 
 class ThriftHive_execute_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHive_execute_args(const ThriftHive_execute_args&);
+  ThriftHive_execute_args& operator=(const ThriftHive_execute_args&);
   ThriftHive_execute_args() : query() {
   }
 
-  virtual ~ThriftHive_execute_args() throw() {}
-
+  virtual ~ThriftHive_execute_args() throw();
   std::string query;
 
   _ThriftHive_execute_args__isset __isset;
 
-  void __set_query(const std::string& val) {
-    query = val;
-  }
+  void __set_query(const std::string& val);
 
   bool operator == (const ThriftHive_execute_args & rhs) const
   {
@@ -119,41 +121,47 @@ class ThriftHive_execute_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_execute_args& obj);
 };
 
 
 class ThriftHive_execute_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHive_execute_pargs() throw() {}
 
+  virtual ~ThriftHive_execute_pargs() throw();
   const std::string* query;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_execute_pargs& obj);
 };
 
 typedef struct _ThriftHive_execute_result__isset {
   _ThriftHive_execute_result__isset() : ex(false) {}
-  bool ex;
+  bool ex :1;
 } _ThriftHive_execute_result__isset;
 
 class ThriftHive_execute_result {
  public:
 
+  static const char* ascii_fingerprint; // = "6AC6FD61CA5E3524E0174B0B96D6F9C0";
+  static const uint8_t binary_fingerprint[16]; // = {0x6A,0xC6,0xFD,0x61,0xCA,0x5E,0x35,0x24,0xE0,0x17,0x4B,0x0B,0x96,0xD6,0xF9,0xC0};
+
+  ThriftHive_execute_result(const ThriftHive_execute_result&);
+  ThriftHive_execute_result& operator=(const ThriftHive_execute_result&);
   ThriftHive_execute_result() {
   }
 
-  virtual ~ThriftHive_execute_result() throw() {}
-
+  virtual ~ThriftHive_execute_result() throw();
   HiveServerException ex;
 
   _ThriftHive_execute_result__isset __isset;
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_execute_result & rhs) const
   {
@@ -170,36 +178,44 @@ class ThriftHive_execute_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_execute_result& obj);
 };
 
 typedef struct _ThriftHive_execute_presult__isset {
   _ThriftHive_execute_presult__isset() : ex(false) {}
-  bool ex;
+  bool ex :1;
 } _ThriftHive_execute_presult__isset;
 
 class ThriftHive_execute_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "6AC6FD61CA5E3524E0174B0B96D6F9C0";
+  static const uint8_t binary_fingerprint[16]; // = {0x6A,0xC6,0xFD,0x61,0xCA,0x5E,0x35,0x24,0xE0,0x17,0x4B,0x0B,0x96,0xD6,0xF9,0xC0};
 
-  virtual ~ThriftHive_execute_presult() throw() {}
 
+  virtual ~ThriftHive_execute_presult() throw();
   HiveServerException ex;
 
   _ThriftHive_execute_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_execute_presult& obj);
 };
 
 
 class ThriftHive_fetchOne_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_fetchOne_args(const ThriftHive_fetchOne_args&);
+  ThriftHive_fetchOne_args& operator=(const ThriftHive_fetchOne_args&);
   ThriftHive_fetchOne_args() {
   }
 
-  virtual ~ThriftHive_fetchOne_args() throw() {}
-
+  virtual ~ThriftHive_fetchOne_args() throw();
 
   bool operator == (const ThriftHive_fetchOne_args & /* rhs */) const
   {
@@ -214,46 +230,50 @@ class ThriftHive_fetchOne_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchOne_args& obj);
 };
 
 
 class ThriftHive_fetchOne_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_fetchOne_pargs() throw() {}
 
+  virtual ~ThriftHive_fetchOne_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchOne_pargs& obj);
 };
 
 typedef struct _ThriftHive_fetchOne_result__isset {
   _ThriftHive_fetchOne_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchOne_result__isset;
 
 class ThriftHive_fetchOne_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BD5C3537D3AE5C0248BD3B45C053AE32";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x5C,0x35,0x37,0xD3,0xAE,0x5C,0x02,0x48,0xBD,0x3B,0x45,0xC0,0x53,0xAE,0x32};
+
+  ThriftHive_fetchOne_result(const ThriftHive_fetchOne_result&);
+  ThriftHive_fetchOne_result& operator=(const ThriftHive_fetchOne_result&);
   ThriftHive_fetchOne_result() : success() {
   }
 
-  virtual ~ThriftHive_fetchOne_result() throw() {}
-
+  virtual ~ThriftHive_fetchOne_result() throw();
   std::string success;
   HiveServerException ex;
 
   _ThriftHive_fetchOne_result__isset __isset;
 
-  void __set_success(const std::string& val) {
-    success = val;
-  }
+  void __set_success(const std::string& val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_fetchOne_result & rhs) const
   {
@@ -272,20 +292,23 @@ class ThriftHive_fetchOne_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchOne_result& obj);
 };
 
 typedef struct _ThriftHive_fetchOne_presult__isset {
   _ThriftHive_fetchOne_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchOne_presult__isset;
 
 class ThriftHive_fetchOne_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BD5C3537D3AE5C0248BD3B45C053AE32";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x5C,0x35,0x37,0xD3,0xAE,0x5C,0x02,0x48,0xBD,0x3B,0x45,0xC0,0x53,0xAE,0x32};
 
-  virtual ~ThriftHive_fetchOne_presult() throw() {}
 
+  virtual ~ThriftHive_fetchOne_presult() throw();
   std::string* success;
   HiveServerException ex;
 
@@ -293,28 +316,31 @@ class ThriftHive_fetchOne_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchOne_presult& obj);
 };
 
 typedef struct _ThriftHive_fetchN_args__isset {
   _ThriftHive_fetchN_args__isset() : numRows(false) {}
-  bool numRows;
+  bool numRows :1;
 } _ThriftHive_fetchN_args__isset;
 
 class ThriftHive_fetchN_args {
  public:
 
+  static const char* ascii_fingerprint; // = "E86CACEB22240450EDCBEFC3A83970E4";
+  static const uint8_t binary_fingerprint[16]; // = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
+
+  ThriftHive_fetchN_args(const ThriftHive_fetchN_args&);
+  ThriftHive_fetchN_args& operator=(const ThriftHive_fetchN_args&);
   ThriftHive_fetchN_args() : numRows(0) {
   }
 
-  virtual ~ThriftHive_fetchN_args() throw() {}
-
+  virtual ~ThriftHive_fetchN_args() throw();
   int32_t numRows;
 
   _ThriftHive_fetchN_args__isset __isset;
 
-  void __set_numRows(const int32_t val) {
-    numRows = val;
-  }
+  void __set_numRows(const int32_t val);
 
   bool operator == (const ThriftHive_fetchN_args & rhs) const
   {
@@ -331,47 +357,51 @@ class ThriftHive_fetchN_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchN_args& obj);
 };
 
 
 class ThriftHive_fetchN_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "E86CACEB22240450EDCBEFC3A83970E4";
+  static const uint8_t binary_fingerprint[16]; // = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
 
-  virtual ~ThriftHive_fetchN_pargs() throw() {}
 
+  virtual ~ThriftHive_fetchN_pargs() throw();
   const int32_t* numRows;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchN_pargs& obj);
 };
 
 typedef struct _ThriftHive_fetchN_result__isset {
   _ThriftHive_fetchN_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchN_result__isset;
 
 class ThriftHive_fetchN_result {
  public:
 
+  static const char* ascii_fingerprint; // = "EB142A6BE66D8EE6065D07106EABD55D";
+  static const uint8_t binary_fingerprint[16]; // = {0xEB,0x14,0x2A,0x6B,0xE6,0x6D,0x8E,0xE6,0x06,0x5D,0x07,0x10,0x6E,0xAB,0xD5,0x5D};
+
+  ThriftHive_fetchN_result(const ThriftHive_fetchN_result&);
+  ThriftHive_fetchN_result& operator=(const ThriftHive_fetchN_result&);
   ThriftHive_fetchN_result() {
   }
 
-  virtual ~ThriftHive_fetchN_result() throw() {}
-
+  virtual ~ThriftHive_fetchN_result() throw();
   std::vector<std::string>  success;
   HiveServerException ex;
 
   _ThriftHive_fetchN_result__isset __isset;
 
-  void __set_success(const std::vector<std::string> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<std::string> & val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_fetchN_result & rhs) const
   {
@@ -390,20 +420,23 @@ class ThriftHive_fetchN_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchN_result& obj);
 };
 
 typedef struct _ThriftHive_fetchN_presult__isset {
   _ThriftHive_fetchN_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchN_presult__isset;
 
 class ThriftHive_fetchN_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "EB142A6BE66D8EE6065D07106EABD55D";
+  static const uint8_t binary_fingerprint[16]; // = {0xEB,0x14,0x2A,0x6B,0xE6,0x6D,0x8E,0xE6,0x06,0x5D,0x07,0x10,0x6E,0xAB,0xD5,0x5D};
 
-  virtual ~ThriftHive_fetchN_presult() throw() {}
 
+  virtual ~ThriftHive_fetchN_presult() throw();
   std::vector<std::string> * success;
   HiveServerException ex;
 
@@ -411,17 +444,22 @@ class ThriftHive_fetchN_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchN_presult& obj);
 };
 
 
 class ThriftHive_fetchAll_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_fetchAll_args(const ThriftHive_fetchAll_args&);
+  ThriftHive_fetchAll_args& operator=(const ThriftHive_fetchAll_args&);
   ThriftHive_fetchAll_args() {
   }
 
-  virtual ~ThriftHive_fetchAll_args() throw() {}
-
+  virtual ~ThriftHive_fetchAll_args() throw();
 
   bool operator == (const ThriftHive_fetchAll_args & /* rhs */) const
   {
@@ -436,46 +474,50 @@ class ThriftHive_fetchAll_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchAll_args& obj);
 };
 
 
 class ThriftHive_fetchAll_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_fetchAll_pargs() throw() {}
 
+  virtual ~ThriftHive_fetchAll_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchAll_pargs& obj);
 };
 
 typedef struct _ThriftHive_fetchAll_result__isset {
   _ThriftHive_fetchAll_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchAll_result__isset;
 
 class ThriftHive_fetchAll_result {
  public:
 
+  static const char* ascii_fingerprint; // = "EB142A6BE66D8EE6065D07106EABD55D";
+  static const uint8_t binary_fingerprint[16]; // = {0xEB,0x14,0x2A,0x6B,0xE6,0x6D,0x8E,0xE6,0x06,0x5D,0x07,0x10,0x6E,0xAB,0xD5,0x5D};
+
+  ThriftHive_fetchAll_result(const ThriftHive_fetchAll_result&);
+  ThriftHive_fetchAll_result& operator=(const ThriftHive_fetchAll_result&);
   ThriftHive_fetchAll_result() {
   }
 
-  virtual ~ThriftHive_fetchAll_result() throw() {}
-
+  virtual ~ThriftHive_fetchAll_result() throw();
   std::vector<std::string>  success;
   HiveServerException ex;
 
   _ThriftHive_fetchAll_result__isset __isset;
 
-  void __set_success(const std::vector<std::string> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<std::string> & val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_fetchAll_result & rhs) const
   {
@@ -494,20 +536,23 @@ class ThriftHive_fetchAll_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchAll_result& obj);
 };
 
 typedef struct _ThriftHive_fetchAll_presult__isset {
   _ThriftHive_fetchAll_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_fetchAll_presult__isset;
 
 class ThriftHive_fetchAll_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "EB142A6BE66D8EE6065D07106EABD55D";
+  static const uint8_t binary_fingerprint[16]; // = {0xEB,0x14,0x2A,0x6B,0xE6,0x6D,0x8E,0xE6,0x06,0x5D,0x07,0x10,0x6E,0xAB,0xD5,0x5D};
 
-  virtual ~ThriftHive_fetchAll_presult() throw() {}
 
+  virtual ~ThriftHive_fetchAll_presult() throw();
   std::vector<std::string> * success;
   HiveServerException ex;
 
@@ -515,17 +560,22 @@ class ThriftHive_fetchAll_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_fetchAll_presult& obj);
 };
 
 
 class ThriftHive_getSchema_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_getSchema_args(const ThriftHive_getSchema_args&);
+  ThriftHive_getSchema_args& operator=(const ThriftHive_getSchema_args&);
   ThriftHive_getSchema_args() {
   }
 
-  virtual ~ThriftHive_getSchema_args() throw() {}
-
+  virtual ~ThriftHive_getSchema_args() throw();
 
   bool operator == (const ThriftHive_getSchema_args & /* rhs */) const
   {
@@ -540,46 +590,50 @@ class ThriftHive_getSchema_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getSchema_args& obj);
 };
 
 
 class ThriftHive_getSchema_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_getSchema_pargs() throw() {}
 
+  virtual ~ThriftHive_getSchema_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getSchema_pargs& obj);
 };
 
 typedef struct _ThriftHive_getSchema_result__isset {
   _ThriftHive_getSchema_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getSchema_result__isset;
 
 class ThriftHive_getSchema_result {
  public:
 
+  static const char* ascii_fingerprint; // = "FCFAE75CC7093F1A3926C2AD58A6FFD1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFC,0xFA,0xE7,0x5C,0xC7,0x09,0x3F,0x1A,0x39,0x26,0xC2,0xAD,0x58,0xA6,0xFF,0xD1};
+
+  ThriftHive_getSchema_result(const ThriftHive_getSchema_result&);
+  ThriftHive_getSchema_result& operator=(const ThriftHive_getSchema_result&);
   ThriftHive_getSchema_result() {
   }
 
-  virtual ~ThriftHive_getSchema_result() throw() {}
-
+  virtual ~ThriftHive_getSchema_result() throw();
    ::Apache::Hadoop::Hive::Schema success;
   HiveServerException ex;
 
   _ThriftHive_getSchema_result__isset __isset;
 
-  void __set_success(const  ::Apache::Hadoop::Hive::Schema& val) {
-    success = val;
-  }
+  void __set_success(const  ::Apache::Hadoop::Hive::Schema& val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_getSchema_result & rhs) const
   {
@@ -598,20 +652,23 @@ class ThriftHive_getSchema_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getSchema_result& obj);
 };
 
 typedef struct _ThriftHive_getSchema_presult__isset {
   _ThriftHive_getSchema_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getSchema_presult__isset;
 
 class ThriftHive_getSchema_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "FCFAE75CC7093F1A3926C2AD58A6FFD1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFC,0xFA,0xE7,0x5C,0xC7,0x09,0x3F,0x1A,0x39,0x26,0xC2,0xAD,0x58,0xA6,0xFF,0xD1};
 
-  virtual ~ThriftHive_getSchema_presult() throw() {}
 
+  virtual ~ThriftHive_getSchema_presult() throw();
    ::Apache::Hadoop::Hive::Schema* success;
   HiveServerException ex;
 
@@ -619,17 +676,22 @@ class ThriftHive_getSchema_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getSchema_presult& obj);
 };
 
 
 class ThriftHive_getThriftSchema_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_getThriftSchema_args(const ThriftHive_getThriftSchema_args&);
+  ThriftHive_getThriftSchema_args& operator=(const ThriftHive_getThriftSchema_args&);
   ThriftHive_getThriftSchema_args() {
   }
 
-  virtual ~ThriftHive_getThriftSchema_args() throw() {}
-
+  virtual ~ThriftHive_getThriftSchema_args() throw();
 
   bool operator == (const ThriftHive_getThriftSchema_args & /* rhs */) const
   {
@@ -644,46 +706,50 @@ class ThriftHive_getThriftSchema_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getThriftSchema_args& obj);
 };
 
 
 class ThriftHive_getThriftSchema_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_getThriftSchema_pargs() throw() {}
 
+  virtual ~ThriftHive_getThriftSchema_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getThriftSchema_pargs& obj);
 };
 
 typedef struct _ThriftHive_getThriftSchema_result__isset {
   _ThriftHive_getThriftSchema_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getThriftSchema_result__isset;
 
 class ThriftHive_getThriftSchema_result {
  public:
 
+  static const char* ascii_fingerprint; // = "FCFAE75CC7093F1A3926C2AD58A6FFD1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFC,0xFA,0xE7,0x5C,0xC7,0x09,0x3F,0x1A,0x39,0x26,0xC2,0xAD,0x58,0xA6,0xFF,0xD1};
+
+  ThriftHive_getThriftSchema_result(const ThriftHive_getThriftSchema_result&);
+  ThriftHive_getThriftSchema_result& operator=(const ThriftHive_getThriftSchema_result&);
   ThriftHive_getThriftSchema_result() {
   }
 
-  virtual ~ThriftHive_getThriftSchema_result() throw() {}
-
+  virtual ~ThriftHive_getThriftSchema_result() throw();
    ::Apache::Hadoop::Hive::Schema success;
   HiveServerException ex;
 
   _ThriftHive_getThriftSchema_result__isset __isset;
 
-  void __set_success(const  ::Apache::Hadoop::Hive::Schema& val) {
-    success = val;
-  }
+  void __set_success(const  ::Apache::Hadoop::Hive::Schema& val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_getThriftSchema_result & rhs) const
   {
@@ -702,20 +768,23 @@ class ThriftHive_getThriftSchema_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getThriftSchema_result& obj);
 };
 
 typedef struct _ThriftHive_getThriftSchema_presult__isset {
   _ThriftHive_getThriftSchema_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getThriftSchema_presult__isset;
 
 class ThriftHive_getThriftSchema_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "FCFAE75CC7093F1A3926C2AD58A6FFD1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFC,0xFA,0xE7,0x5C,0xC7,0x09,0x3F,0x1A,0x39,0x26,0xC2,0xAD,0x58,0xA6,0xFF,0xD1};
 
-  virtual ~ThriftHive_getThriftSchema_presult() throw() {}
 
+  virtual ~ThriftHive_getThriftSchema_presult() throw();
    ::Apache::Hadoop::Hive::Schema* success;
   HiveServerException ex;
 
@@ -723,17 +792,22 @@ class ThriftHive_getThriftSchema_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getThriftSchema_presult& obj);
 };
 
 
 class ThriftHive_getClusterStatus_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_getClusterStatus_args(const ThriftHive_getClusterStatus_args&);
+  ThriftHive_getClusterStatus_args& operator=(const ThriftHive_getClusterStatus_args&);
   ThriftHive_getClusterStatus_args() {
   }
 
-  virtual ~ThriftHive_getClusterStatus_args() throw() {}
-
+  virtual ~ThriftHive_getClusterStatus_args() throw();
 
   bool operator == (const ThriftHive_getClusterStatus_args & /* rhs */) const
   {
@@ -748,46 +822,50 @@ class ThriftHive_getClusterStatus_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getClusterStatus_args& obj);
 };
 
 
 class ThriftHive_getClusterStatus_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_getClusterStatus_pargs() throw() {}
 
+  virtual ~ThriftHive_getClusterStatus_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getClusterStatus_pargs& obj);
 };
 
 typedef struct _ThriftHive_getClusterStatus_result__isset {
   _ThriftHive_getClusterStatus_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getClusterStatus_result__isset;
 
 class ThriftHive_getClusterStatus_result {
  public:
 
+  static const char* ascii_fingerprint; // = "F486E00F8F0F2B6A17A0371997BB7B87";
+  static const uint8_t binary_fingerprint[16]; // = {0xF4,0x86,0xE0,0x0F,0x8F,0x0F,0x2B,0x6A,0x17,0xA0,0x37,0x19,0x97,0xBB,0x7B,0x87};
+
+  ThriftHive_getClusterStatus_result(const ThriftHive_getClusterStatus_result&);
+  ThriftHive_getClusterStatus_result& operator=(const ThriftHive_getClusterStatus_result&);
   ThriftHive_getClusterStatus_result() {
   }
 
-  virtual ~ThriftHive_getClusterStatus_result() throw() {}
-
+  virtual ~ThriftHive_getClusterStatus_result() throw();
   HiveClusterStatus success;
   HiveServerException ex;
 
   _ThriftHive_getClusterStatus_result__isset __isset;
 
-  void __set_success(const HiveClusterStatus& val) {
-    success = val;
-  }
+  void __set_success(const HiveClusterStatus& val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_getClusterStatus_result & rhs) const
   {
@@ -806,20 +884,23 @@ class ThriftHive_getClusterStatus_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getClusterStatus_result& obj);
 };
 
 typedef struct _ThriftHive_getClusterStatus_presult__isset {
   _ThriftHive_getClusterStatus_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getClusterStatus_presult__isset;
 
 class ThriftHive_getClusterStatus_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "F486E00F8F0F2B6A17A0371997BB7B87";
+  static const uint8_t binary_fingerprint[16]; // = {0xF4,0x86,0xE0,0x0F,0x8F,0x0F,0x2B,0x6A,0x17,0xA0,0x37,0x19,0x97,0xBB,0x7B,0x87};
 
-  virtual ~ThriftHive_getClusterStatus_presult() throw() {}
 
+  virtual ~ThriftHive_getClusterStatus_presult() throw();
   HiveClusterStatus* success;
   HiveServerException ex;
 
@@ -827,17 +908,22 @@ class ThriftHive_getClusterStatus_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getClusterStatus_presult& obj);
 };
 
 
 class ThriftHive_getQueryPlan_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_getQueryPlan_args(const ThriftHive_getQueryPlan_args&);
+  ThriftHive_getQueryPlan_args& operator=(const ThriftHive_getQueryPlan_args&);
   ThriftHive_getQueryPlan_args() {
   }
 
-  virtual ~ThriftHive_getQueryPlan_args() throw() {}
-
+  virtual ~ThriftHive_getQueryPlan_args() throw();
 
   bool operator == (const ThriftHive_getQueryPlan_args & /* rhs */) const
   {
@@ -852,46 +938,50 @@ class ThriftHive_getQueryPlan_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getQueryPlan_args& obj);
 };
 
 
 class ThriftHive_getQueryPlan_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_getQueryPlan_pargs() throw() {}
 
+  virtual ~ThriftHive_getQueryPlan_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getQueryPlan_pargs& obj);
 };
 
 typedef struct _ThriftHive_getQueryPlan_result__isset {
   _ThriftHive_getQueryPlan_result__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getQueryPlan_result__isset;
 
 class ThriftHive_getQueryPlan_result {
  public:
 
+  static const char* ascii_fingerprint; // = "0263544CFF7194CEE7DC6128DD5941ED";
+  static const uint8_t binary_fingerprint[16]; // = {0x02,0x63,0x54,0x4C,0xFF,0x71,0x94,0xCE,0xE7,0xDC,0x61,0x28,0xDD,0x59,0x41,0xED};
+
+  ThriftHive_getQueryPlan_result(const ThriftHive_getQueryPlan_result&);
+  ThriftHive_getQueryPlan_result& operator=(const ThriftHive_getQueryPlan_result&);
   ThriftHive_getQueryPlan_result() {
   }
 
-  virtual ~ThriftHive_getQueryPlan_result() throw() {}
-
+  virtual ~ThriftHive_getQueryPlan_result() throw();
    ::Apache::Hadoop::Hive::QueryPlan success;
   HiveServerException ex;
 
   _ThriftHive_getQueryPlan_result__isset __isset;
 
-  void __set_success(const  ::Apache::Hadoop::Hive::QueryPlan& val) {
-    success = val;
-  }
+  void __set_success(const  ::Apache::Hadoop::Hive::QueryPlan& val);
 
-  void __set_ex(const HiveServerException& val) {
-    ex = val;
-  }
+  void __set_ex(const HiveServerException& val);
 
   bool operator == (const ThriftHive_getQueryPlan_result & rhs) const
   {
@@ -910,20 +1000,23 @@ class ThriftHive_getQueryPlan_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getQueryPlan_result& obj);
 };
 
 typedef struct _ThriftHive_getQueryPlan_presult__isset {
   _ThriftHive_getQueryPlan_presult__isset() : success(false), ex(false) {}
-  bool success;
-  bool ex;
+  bool success :1;
+  bool ex :1;
 } _ThriftHive_getQueryPlan_presult__isset;
 
 class ThriftHive_getQueryPlan_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "0263544CFF7194CEE7DC6128DD5941ED";
+  static const uint8_t binary_fingerprint[16]; // = {0x02,0x63,0x54,0x4C,0xFF,0x71,0x94,0xCE,0xE7,0xDC,0x61,0x28,0xDD,0x59,0x41,0xED};
 
-  virtual ~ThriftHive_getQueryPlan_presult() throw() {}
 
+  virtual ~ThriftHive_getQueryPlan_presult() throw();
    ::Apache::Hadoop::Hive::QueryPlan* success;
   HiveServerException ex;
 
@@ -931,17 +1024,22 @@ class ThriftHive_getQueryPlan_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_getQueryPlan_presult& obj);
 };
 
 
 class ThriftHive_clean_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_clean_args(const ThriftHive_clean_args&);
+  ThriftHive_clean_args& operator=(const ThriftHive_clean_args&);
   ThriftHive_clean_args() {
   }
 
-  virtual ~ThriftHive_clean_args() throw() {}
-
+  virtual ~ThriftHive_clean_args() throw();
 
   bool operator == (const ThriftHive_clean_args & /* rhs */) const
   {
@@ -956,29 +1054,37 @@ class ThriftHive_clean_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_clean_args& obj);
 };
 
 
 class ThriftHive_clean_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_clean_pargs() throw() {}
 
+  virtual ~ThriftHive_clean_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_clean_pargs& obj);
 };
 
 
 class ThriftHive_clean_result {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHive_clean_result(const ThriftHive_clean_result&);
+  ThriftHive_clean_result& operator=(const ThriftHive_clean_result&);
   ThriftHive_clean_result() {
   }
 
-  virtual ~ThriftHive_clean_result() throw() {}
-
+  virtual ~ThriftHive_clean_result() throw();
 
   bool operator == (const ThriftHive_clean_result & /* rhs */) const
   {
@@ -993,26 +1099,29 @@ class ThriftHive_clean_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_clean_result& obj);
 };
 
 
 class ThriftHive_clean_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHive_clean_presult() throw() {}
 
+  virtual ~ThriftHive_clean_presult() throw();
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHive_clean_presult& obj);
 };
 
 class ThriftHiveClient : virtual public ThriftHiveIf, public  ::Apache::Hadoop::Hive::ThriftHiveMetastoreClient {
  public:
   ThriftHiveClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> prot) :
      ::Apache::Hadoop::Hive::ThriftHiveMetastoreClient(prot, prot) {}
-  ThriftHiveClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr< ::apache::thrift::protocol::TProtocol> oprot) :
-     ::Apache::Hadoop::Hive::ThriftHiveMetastoreClient(iprot, oprot) {}
+  ThriftHiveClient(boost::shared_ptr< ::apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr< ::apache::thrift::protocol::TProtocol> oprot) :     ::Apache::Hadoop::Hive::ThriftHiveMetastoreClient(iprot, oprot) {}
   boost::shared_ptr< ::apache::thrift::protocol::TProtocol> getInputProtocol() {
     return piprot_;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/hive_service_constants.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/hive_service_constants.cpp b/service/src/gen/thrift/gen-cpp/hive_service_constants.cpp
index 3555b03..c3c8482 100644
--- a/service/src/gen/thrift/gen-cpp/hive_service_constants.cpp
+++ b/service/src/gen/thrift/gen-cpp/hive_service_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/hive_service_constants.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/hive_service_constants.h b/service/src/gen/thrift/gen-cpp/hive_service_constants.h
index e27273c..5878dbe 100644
--- a/service/src/gen/thrift/gen-cpp/hive_service_constants.h
+++ b/service/src/gen/thrift/gen-cpp/hive_service_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/hive_service_types.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/hive_service_types.cpp b/service/src/gen/thrift/gen-cpp/hive_service_types.cpp
index 255fb00..4d6cf01 100644
--- a/service/src/gen/thrift/gen-cpp/hive_service_types.cpp
+++ b/service/src/gen/thrift/gen-cpp/hive_service_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "hive_service_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 namespace Apache { namespace Hadoop { namespace Hive {
 
@@ -20,6 +23,35 @@ const char* _kJobTrackerStateNames[] = {
 };
 const std::map<int, const char*> _JobTrackerState_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(2, _kJobTrackerStateValues, _kJobTrackerStateNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
+
+HiveClusterStatus::~HiveClusterStatus() throw() {
+}
+
+
+void HiveClusterStatus::__set_taskTrackers(const int32_t val) {
+  this->taskTrackers = val;
+}
+
+void HiveClusterStatus::__set_mapTasks(const int32_t val) {
+  this->mapTasks = val;
+}
+
+void HiveClusterStatus::__set_reduceTasks(const int32_t val) {
+  this->reduceTasks = val;
+}
+
+void HiveClusterStatus::__set_maxMapTasks(const int32_t val) {
+  this->maxMapTasks = val;
+}
+
+void HiveClusterStatus::__set_maxReduceTasks(const int32_t val) {
+  this->maxReduceTasks = val;
+}
+
+void HiveClusterStatus::__set_state(const JobTrackerState::type val) {
+  this->state = val;
+}
+
 const char* HiveClusterStatus::ascii_fingerprint = "D514EDCFFC86F64A2E924DCD16D4FAD8";
 const uint8_t HiveClusterStatus::binary_fingerprint[16] = {0xD5,0x14,0xED,0xCF,0xFC,0x86,0xF6,0x4A,0x2E,0x92,0x4D,0xCD,0x16,0xD4,0xFA,0xD8};
 
@@ -107,6 +139,7 @@ uint32_t HiveClusterStatus::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t HiveClusterStatus::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("HiveClusterStatus");
 
   xfer += oprot->writeFieldBegin("taskTrackers", ::apache::thrift::protocol::T_I32, 1);
@@ -135,6 +168,7 @@ uint32_t HiveClusterStatus::write(::apache::thrift::protocol::TProtocol* oprot)
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -149,6 +183,55 @@ void swap(HiveClusterStatus &a, HiveClusterStatus &b) {
   swap(a.__isset, b.__isset);
 }
 
+HiveClusterStatus::HiveClusterStatus(const HiveClusterStatus& other1) {
+  taskTrackers = other1.taskTrackers;
+  mapTasks = other1.mapTasks;
+  reduceTasks = other1.reduceTasks;
+  maxMapTasks = other1.maxMapTasks;
+  maxReduceTasks = other1.maxReduceTasks;
+  state = other1.state;
+  __isset = other1.__isset;
+}
+HiveClusterStatus& HiveClusterStatus::operator=(const HiveClusterStatus& other2) {
+  taskTrackers = other2.taskTrackers;
+  mapTasks = other2.mapTasks;
+  reduceTasks = other2.reduceTasks;
+  maxMapTasks = other2.maxMapTasks;
+  maxReduceTasks = other2.maxReduceTasks;
+  state = other2.state;
+  __isset = other2.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const HiveClusterStatus& obj) {
+  using apache::thrift::to_string;
+  out << "HiveClusterStatus(";
+  out << "taskTrackers=" << to_string(obj.taskTrackers);
+  out << ", " << "mapTasks=" << to_string(obj.mapTasks);
+  out << ", " << "reduceTasks=" << to_string(obj.reduceTasks);
+  out << ", " << "maxMapTasks=" << to_string(obj.maxMapTasks);
+  out << ", " << "maxReduceTasks=" << to_string(obj.maxReduceTasks);
+  out << ", " << "state=" << to_string(obj.state);
+  out << ")";
+  return out;
+}
+
+
+HiveServerException::~HiveServerException() throw() {
+}
+
+
+void HiveServerException::__set_message(const std::string& val) {
+  this->message = val;
+}
+
+void HiveServerException::__set_errorCode(const int32_t val) {
+  this->errorCode = val;
+}
+
+void HiveServerException::__set_SQLState(const std::string& val) {
+  this->SQLState = val;
+}
+
 const char* HiveServerException::ascii_fingerprint = "70563A0628F75DF9555F4D24690B1E26";
 const uint8_t HiveServerException::binary_fingerprint[16] = {0x70,0x56,0x3A,0x06,0x28,0xF7,0x5D,0xF9,0x55,0x5F,0x4D,0x24,0x69,0x0B,0x1E,0x26};
 
@@ -210,6 +293,7 @@ uint32_t HiveServerException::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t HiveServerException::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("HiveServerException");
 
   xfer += oprot->writeFieldBegin("message", ::apache::thrift::protocol::T_STRING, 1);
@@ -226,6 +310,7 @@ uint32_t HiveServerException::write(::apache::thrift::protocol::TProtocol* oprot
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -237,4 +322,27 @@ void swap(HiveServerException &a, HiveServerException &b) {
   swap(a.__isset, b.__isset);
 }
 
+HiveServerException::HiveServerException(const HiveServerException& other3) : TException() {
+  message = other3.message;
+  errorCode = other3.errorCode;
+  SQLState = other3.SQLState;
+  __isset = other3.__isset;
+}
+HiveServerException& HiveServerException::operator=(const HiveServerException& other4) {
+  message = other4.message;
+  errorCode = other4.errorCode;
+  SQLState = other4.SQLState;
+  __isset = other4.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const HiveServerException& obj) {
+  using apache::thrift::to_string;
+  out << "HiveServerException(";
+  out << "message=" << to_string(obj.message);
+  out << ", " << "errorCode=" << to_string(obj.errorCode);
+  out << ", " << "SQLState=" << to_string(obj.SQLState);
+  out << ")";
+  return out;
+}
+
 }}} // namespace

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/hive_service_types.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/hive_service_types.h b/service/src/gen/thrift/gen-cpp/hive_service_types.h
index bc0e652..7fea88c 100644
--- a/service/src/gen/thrift/gen-cpp/hive_service_types.h
+++ b/service/src/gen/thrift/gen-cpp/hive_service_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef hive_service_TYPES_H
 #define hive_service_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 #include "fb303_types.h"
 #include "hive_metastore_types.h"
 #include "queryplan_types.h"
@@ -28,14 +31,18 @@ struct JobTrackerState {
 
 extern const std::map<int, const char*> _JobTrackerState_VALUES_TO_NAMES;
 
+class HiveClusterStatus;
+
+class HiveServerException;
+
 typedef struct _HiveClusterStatus__isset {
   _HiveClusterStatus__isset() : taskTrackers(false), mapTasks(false), reduceTasks(false), maxMapTasks(false), maxReduceTasks(false), state(false) {}
-  bool taskTrackers;
-  bool mapTasks;
-  bool reduceTasks;
-  bool maxMapTasks;
-  bool maxReduceTasks;
-  bool state;
+  bool taskTrackers :1;
+  bool mapTasks :1;
+  bool reduceTasks :1;
+  bool maxMapTasks :1;
+  bool maxReduceTasks :1;
+  bool state :1;
 } _HiveClusterStatus__isset;
 
 class HiveClusterStatus {
@@ -44,11 +51,12 @@ class HiveClusterStatus {
   static const char* ascii_fingerprint; // = "D514EDCFFC86F64A2E924DCD16D4FAD8";
   static const uint8_t binary_fingerprint[16]; // = {0xD5,0x14,0xED,0xCF,0xFC,0x86,0xF6,0x4A,0x2E,0x92,0x4D,0xCD,0x16,0xD4,0xFA,0xD8};
 
+  HiveClusterStatus(const HiveClusterStatus&);
+  HiveClusterStatus& operator=(const HiveClusterStatus&);
   HiveClusterStatus() : taskTrackers(0), mapTasks(0), reduceTasks(0), maxMapTasks(0), maxReduceTasks(0), state((JobTrackerState::type)0) {
   }
 
-  virtual ~HiveClusterStatus() throw() {}
-
+  virtual ~HiveClusterStatus() throw();
   int32_t taskTrackers;
   int32_t mapTasks;
   int32_t reduceTasks;
@@ -58,29 +66,17 @@ class HiveClusterStatus {
 
   _HiveClusterStatus__isset __isset;
 
-  void __set_taskTrackers(const int32_t val) {
-    taskTrackers = val;
-  }
+  void __set_taskTrackers(const int32_t val);
 
-  void __set_mapTasks(const int32_t val) {
-    mapTasks = val;
-  }
+  void __set_mapTasks(const int32_t val);
 
-  void __set_reduceTasks(const int32_t val) {
-    reduceTasks = val;
-  }
+  void __set_reduceTasks(const int32_t val);
 
-  void __set_maxMapTasks(const int32_t val) {
-    maxMapTasks = val;
-  }
+  void __set_maxMapTasks(const int32_t val);
 
-  void __set_maxReduceTasks(const int32_t val) {
-    maxReduceTasks = val;
-  }
+  void __set_maxReduceTasks(const int32_t val);
 
-  void __set_state(const JobTrackerState::type val) {
-    state = val;
-  }
+  void __set_state(const JobTrackerState::type val);
 
   bool operator == (const HiveClusterStatus & rhs) const
   {
@@ -107,15 +103,16 @@ class HiveClusterStatus {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const HiveClusterStatus& obj);
 };
 
 void swap(HiveClusterStatus &a, HiveClusterStatus &b);
 
 typedef struct _HiveServerException__isset {
   _HiveServerException__isset() : message(false), errorCode(false), SQLState(false) {}
-  bool message;
-  bool errorCode;
-  bool SQLState;
+  bool message :1;
+  bool errorCode :1;
+  bool SQLState :1;
 } _HiveServerException__isset;
 
 class HiveServerException : public ::apache::thrift::TException {
@@ -124,28 +121,23 @@ class HiveServerException : public ::apache::thrift::TException {
   static const char* ascii_fingerprint; // = "70563A0628F75DF9555F4D24690B1E26";
   static const uint8_t binary_fingerprint[16]; // = {0x70,0x56,0x3A,0x06,0x28,0xF7,0x5D,0xF9,0x55,0x5F,0x4D,0x24,0x69,0x0B,0x1E,0x26};
 
+  HiveServerException(const HiveServerException&);
+  HiveServerException& operator=(const HiveServerException&);
   HiveServerException() : message(), errorCode(0), SQLState() {
   }
 
-  virtual ~HiveServerException() throw() {}
-
+  virtual ~HiveServerException() throw();
   std::string message;
   int32_t errorCode;
   std::string SQLState;
 
   _HiveServerException__isset __isset;
 
-  void __set_message(const std::string& val) {
-    message = val;
-  }
+  void __set_message(const std::string& val);
 
-  void __set_errorCode(const int32_t val) {
-    errorCode = val;
-  }
+  void __set_errorCode(const int32_t val);
 
-  void __set_SQLState(const std::string& val) {
-    SQLState = val;
-  }
+  void __set_SQLState(const std::string& val);
 
   bool operator == (const HiveServerException & rhs) const
   {
@@ -166,6 +158,7 @@ class HiveServerException : public ::apache::thrift::TException {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const HiveServerException& obj);
 };
 
 void swap(HiveServerException &a, HiveServerException &b);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveClusterStatus.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveClusterStatus.java b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveClusterStatus.java
index 11566e5..9bfbea9 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveClusterStatus.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveClusterStatus.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.service;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HiveClusterStatus implements org.apache.thrift.TBase<HiveClusterStatus, HiveClusterStatus._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HiveClusterStatus implements org.apache.thrift.TBase<HiveClusterStatus, HiveClusterStatus._Fields>, java.io.Serializable, Cloneable, Comparable<HiveClusterStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HiveClusterStatus");
 
   private static final org.apache.thrift.protocol.TField TASK_TRACKERS_FIELD_DESC = new org.apache.thrift.protocol.TField("taskTrackers", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -529,105 +533,105 @@ public class HiveClusterStatus implements org.apache.thrift.TBase<HiveClusterSta
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_taskTrackers = true;
-    builder.append(present_taskTrackers);
+    list.add(present_taskTrackers);
     if (present_taskTrackers)
-      builder.append(taskTrackers);
+      list.add(taskTrackers);
 
     boolean present_mapTasks = true;
-    builder.append(present_mapTasks);
+    list.add(present_mapTasks);
     if (present_mapTasks)
-      builder.append(mapTasks);
+      list.add(mapTasks);
 
     boolean present_reduceTasks = true;
-    builder.append(present_reduceTasks);
+    list.add(present_reduceTasks);
     if (present_reduceTasks)
-      builder.append(reduceTasks);
+      list.add(reduceTasks);
 
     boolean present_maxMapTasks = true;
-    builder.append(present_maxMapTasks);
+    list.add(present_maxMapTasks);
     if (present_maxMapTasks)
-      builder.append(maxMapTasks);
+      list.add(maxMapTasks);
 
     boolean present_maxReduceTasks = true;
-    builder.append(present_maxReduceTasks);
+    list.add(present_maxReduceTasks);
     if (present_maxReduceTasks)
-      builder.append(maxReduceTasks);
+      list.add(maxReduceTasks);
 
     boolean present_state = true && (isSetState());
-    builder.append(present_state);
+    list.add(present_state);
     if (present_state)
-      builder.append(state.getValue());
+      list.add(state.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HiveClusterStatus other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HiveClusterStatus typedOther = (HiveClusterStatus)other;
 
-    lastComparison = Boolean.valueOf(isSetTaskTrackers()).compareTo(typedOther.isSetTaskTrackers());
+    lastComparison = Boolean.valueOf(isSetTaskTrackers()).compareTo(other.isSetTaskTrackers());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskTrackers()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskTrackers, typedOther.taskTrackers);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskTrackers, other.taskTrackers);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMapTasks()).compareTo(typedOther.isSetMapTasks());
+    lastComparison = Boolean.valueOf(isSetMapTasks()).compareTo(other.isSetMapTasks());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMapTasks()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mapTasks, typedOther.mapTasks);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mapTasks, other.mapTasks);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetReduceTasks()).compareTo(typedOther.isSetReduceTasks());
+    lastComparison = Boolean.valueOf(isSetReduceTasks()).compareTo(other.isSetReduceTasks());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetReduceTasks()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.reduceTasks, typedOther.reduceTasks);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.reduceTasks, other.reduceTasks);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMaxMapTasks()).compareTo(typedOther.isSetMaxMapTasks());
+    lastComparison = Boolean.valueOf(isSetMaxMapTasks()).compareTo(other.isSetMaxMapTasks());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxMapTasks()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxMapTasks, typedOther.maxMapTasks);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxMapTasks, other.maxMapTasks);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMaxReduceTasks()).compareTo(typedOther.isSetMaxReduceTasks());
+    lastComparison = Boolean.valueOf(isSetMaxReduceTasks()).compareTo(other.isSetMaxReduceTasks());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxReduceTasks()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxReduceTasks, typedOther.maxReduceTasks);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxReduceTasks, other.maxReduceTasks);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetState()).compareTo(typedOther.isSetState());
+    lastComparison = Boolean.valueOf(isSetState()).compareTo(other.isSetState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, typedOther.state);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, other.state);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -766,7 +770,7 @@ public class HiveClusterStatus implements org.apache.thrift.TBase<HiveClusterSta
             break;
           case 6: // STATE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.state = JobTrackerState.findByValue(iprot.readI32());
+              struct.state = org.apache.hadoop.hive.service.JobTrackerState.findByValue(iprot.readI32());
               struct.setStateIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -887,7 +891,7 @@ public class HiveClusterStatus implements org.apache.thrift.TBase<HiveClusterSta
         struct.setMaxReduceTasksIsSet(true);
       }
       if (incoming.get(5)) {
-        struct.state = JobTrackerState.findByValue(iprot.readI32());
+        struct.state = org.apache.hadoop.hive.service.JobTrackerState.findByValue(iprot.readI32());
         struct.setStateIsSet(true);
       }
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveServerException.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveServerException.java b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveServerException.java
index 353dc8a..da8d1bc 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveServerException.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/HiveServerException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.service;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HiveServerException extends TException implements org.apache.thrift.TBase<HiveServerException, HiveServerException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HiveServerException extends TException implements org.apache.thrift.TBase<HiveServerException, HiveServerException._Fields>, java.io.Serializable, Cloneable, Comparable<HiveServerException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HiveServerException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -343,60 +347,60 @@ public class HiveServerException extends TException implements org.apache.thrift
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
     boolean present_errorCode = true;
-    builder.append(present_errorCode);
+    list.add(present_errorCode);
     if (present_errorCode)
-      builder.append(errorCode);
+      list.add(errorCode);
 
     boolean present_SQLState = true && (isSetSQLState());
-    builder.append(present_SQLState);
+    list.add(present_SQLState);
     if (present_SQLState)
-      builder.append(SQLState);
+      list.add(SQLState);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HiveServerException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HiveServerException typedOther = (HiveServerException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(typedOther.isSetErrorCode());
+    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(other.isSetErrorCode());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetErrorCode()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, typedOther.errorCode);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, other.errorCode);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSQLState()).compareTo(typedOther.isSetSQLState());
+    lastComparison = Boolean.valueOf(isSetSQLState()).compareTo(other.isSetSQLState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSQLState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.SQLState, typedOther.SQLState);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.SQLState, other.SQLState);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/JobTrackerState.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/JobTrackerState.java b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/JobTrackerState.java
index 5de66c5..ab48bf7 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/JobTrackerState.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/JobTrackerState.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[12/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService_types.h
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService_types.h b/service/src/gen/thrift/gen-cpp/TCLIService_types.h
index 7bceabd..4536b41 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService_types.h
+++ b/service/src/gen/thrift/gen-cpp/TCLIService_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef TCLIService_TYPES_H
 #define TCLIService_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 
 
 namespace apache { namespace hive { namespace service { namespace cli { namespace thrift {
@@ -178,10 +181,158 @@ typedef std::string TPattern;
 
 typedef std::string TPatternOrIdentifier;
 
+class TTypeQualifierValue;
+
+class TTypeQualifiers;
+
+class TPrimitiveTypeEntry;
+
+class TArrayTypeEntry;
+
+class TMapTypeEntry;
+
+class TStructTypeEntry;
+
+class TUnionTypeEntry;
+
+class TUserDefinedTypeEntry;
+
+class TTypeEntry;
+
+class TTypeDesc;
+
+class TColumnDesc;
+
+class TTableSchema;
+
+class TBoolValue;
+
+class TByteValue;
+
+class TI16Value;
+
+class TI32Value;
+
+class TI64Value;
+
+class TDoubleValue;
+
+class TStringValue;
+
+class TColumnValue;
+
+class TRow;
+
+class TBoolColumn;
+
+class TByteColumn;
+
+class TI16Column;
+
+class TI32Column;
+
+class TI64Column;
+
+class TDoubleColumn;
+
+class TStringColumn;
+
+class TBinaryColumn;
+
+class TColumn;
+
+class TRowSet;
+
+class TStatus;
+
+class THandleIdentifier;
+
+class TSessionHandle;
+
+class TOperationHandle;
+
+class TOpenSessionReq;
+
+class TOpenSessionResp;
+
+class TCloseSessionReq;
+
+class TCloseSessionResp;
+
+class TGetInfoValue;
+
+class TGetInfoReq;
+
+class TGetInfoResp;
+
+class TExecuteStatementReq;
+
+class TExecuteStatementResp;
+
+class TGetTypeInfoReq;
+
+class TGetTypeInfoResp;
+
+class TGetCatalogsReq;
+
+class TGetCatalogsResp;
+
+class TGetSchemasReq;
+
+class TGetSchemasResp;
+
+class TGetTablesReq;
+
+class TGetTablesResp;
+
+class TGetTableTypesReq;
+
+class TGetTableTypesResp;
+
+class TGetColumnsReq;
+
+class TGetColumnsResp;
+
+class TGetFunctionsReq;
+
+class TGetFunctionsResp;
+
+class TGetOperationStatusReq;
+
+class TGetOperationStatusResp;
+
+class TCancelOperationReq;
+
+class TCancelOperationResp;
+
+class TCloseOperationReq;
+
+class TCloseOperationResp;
+
+class TGetResultSetMetadataReq;
+
+class TGetResultSetMetadataResp;
+
+class TFetchResultsReq;
+
+class TFetchResultsResp;
+
+class TGetDelegationTokenReq;
+
+class TGetDelegationTokenResp;
+
+class TCancelDelegationTokenReq;
+
+class TCancelDelegationTokenResp;
+
+class TRenewDelegationTokenReq;
+
+class TRenewDelegationTokenResp;
+
 typedef struct _TTypeQualifierValue__isset {
   _TTypeQualifierValue__isset() : i32Value(false), stringValue(false) {}
-  bool i32Value;
-  bool stringValue;
+  bool i32Value :1;
+  bool stringValue :1;
 } _TTypeQualifierValue__isset;
 
 class TTypeQualifierValue {
@@ -190,25 +341,20 @@ class TTypeQualifierValue {
   static const char* ascii_fingerprint; // = "A7801670116150C65ACA43E6F679BA79";
   static const uint8_t binary_fingerprint[16]; // = {0xA7,0x80,0x16,0x70,0x11,0x61,0x50,0xC6,0x5A,0xCA,0x43,0xE6,0xF6,0x79,0xBA,0x79};
 
+  TTypeQualifierValue(const TTypeQualifierValue&);
+  TTypeQualifierValue& operator=(const TTypeQualifierValue&);
   TTypeQualifierValue() : i32Value(0), stringValue() {
   }
 
-  virtual ~TTypeQualifierValue() throw() {}
-
+  virtual ~TTypeQualifierValue() throw();
   int32_t i32Value;
   std::string stringValue;
 
   _TTypeQualifierValue__isset __isset;
 
-  void __set_i32Value(const int32_t val) {
-    i32Value = val;
-    __isset.i32Value = true;
-  }
+  void __set_i32Value(const int32_t val);
 
-  void __set_stringValue(const std::string& val) {
-    stringValue = val;
-    __isset.stringValue = true;
-  }
+  void __set_stringValue(const std::string& val);
 
   bool operator == (const TTypeQualifierValue & rhs) const
   {
@@ -231,6 +377,7 @@ class TTypeQualifierValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TTypeQualifierValue& obj);
 };
 
 void swap(TTypeQualifierValue &a, TTypeQualifierValue &b);
@@ -242,16 +389,15 @@ class TTypeQualifiers {
   static const char* ascii_fingerprint; // = "6C72981CFA989214285648FA8C196C47";
   static const uint8_t binary_fingerprint[16]; // = {0x6C,0x72,0x98,0x1C,0xFA,0x98,0x92,0x14,0x28,0x56,0x48,0xFA,0x8C,0x19,0x6C,0x47};
 
+  TTypeQualifiers(const TTypeQualifiers&);
+  TTypeQualifiers& operator=(const TTypeQualifiers&);
   TTypeQualifiers() {
   }
 
-  virtual ~TTypeQualifiers() throw() {}
-
+  virtual ~TTypeQualifiers() throw();
   std::map<std::string, TTypeQualifierValue>  qualifiers;
 
-  void __set_qualifiers(const std::map<std::string, TTypeQualifierValue> & val) {
-    qualifiers = val;
-  }
+  void __set_qualifiers(const std::map<std::string, TTypeQualifierValue> & val);
 
   bool operator == (const TTypeQualifiers & rhs) const
   {
@@ -268,13 +414,14 @@ class TTypeQualifiers {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TTypeQualifiers& obj);
 };
 
 void swap(TTypeQualifiers &a, TTypeQualifiers &b);
 
 typedef struct _TPrimitiveTypeEntry__isset {
   _TPrimitiveTypeEntry__isset() : typeQualifiers(false) {}
-  bool typeQualifiers;
+  bool typeQualifiers :1;
 } _TPrimitiveTypeEntry__isset;
 
 class TPrimitiveTypeEntry {
@@ -283,24 +430,20 @@ class TPrimitiveTypeEntry {
   static const char* ascii_fingerprint; // = "755674F6A5C8EB47868686AE386FBC1C";
   static const uint8_t binary_fingerprint[16]; // = {0x75,0x56,0x74,0xF6,0xA5,0xC8,0xEB,0x47,0x86,0x86,0x86,0xAE,0x38,0x6F,0xBC,0x1C};
 
+  TPrimitiveTypeEntry(const TPrimitiveTypeEntry&);
+  TPrimitiveTypeEntry& operator=(const TPrimitiveTypeEntry&);
   TPrimitiveTypeEntry() : type((TTypeId::type)0) {
   }
 
-  virtual ~TPrimitiveTypeEntry() throw() {}
-
+  virtual ~TPrimitiveTypeEntry() throw();
   TTypeId::type type;
   TTypeQualifiers typeQualifiers;
 
   _TPrimitiveTypeEntry__isset __isset;
 
-  void __set_type(const TTypeId::type val) {
-    type = val;
-  }
+  void __set_type(const TTypeId::type val);
 
-  void __set_typeQualifiers(const TTypeQualifiers& val) {
-    typeQualifiers = val;
-    __isset.typeQualifiers = true;
-  }
+  void __set_typeQualifiers(const TTypeQualifiers& val);
 
   bool operator == (const TPrimitiveTypeEntry & rhs) const
   {
@@ -321,6 +464,7 @@ class TPrimitiveTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TPrimitiveTypeEntry& obj);
 };
 
 void swap(TPrimitiveTypeEntry &a, TPrimitiveTypeEntry &b);
@@ -332,16 +476,15 @@ class TArrayTypeEntry {
   static const char* ascii_fingerprint; // = "E86CACEB22240450EDCBEFC3A83970E4";
   static const uint8_t binary_fingerprint[16]; // = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
 
+  TArrayTypeEntry(const TArrayTypeEntry&);
+  TArrayTypeEntry& operator=(const TArrayTypeEntry&);
   TArrayTypeEntry() : objectTypePtr(0) {
   }
 
-  virtual ~TArrayTypeEntry() throw() {}
-
+  virtual ~TArrayTypeEntry() throw();
   TTypeEntryPtr objectTypePtr;
 
-  void __set_objectTypePtr(const TTypeEntryPtr val) {
-    objectTypePtr = val;
-  }
+  void __set_objectTypePtr(const TTypeEntryPtr val);
 
   bool operator == (const TArrayTypeEntry & rhs) const
   {
@@ -358,6 +501,7 @@ class TArrayTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TArrayTypeEntry& obj);
 };
 
 void swap(TArrayTypeEntry &a, TArrayTypeEntry &b);
@@ -369,21 +513,18 @@ class TMapTypeEntry {
   static const char* ascii_fingerprint; // = "989D1F1AE8D148D5E2119FFEC4BBBEE3";
   static const uint8_t binary_fingerprint[16]; // = {0x98,0x9D,0x1F,0x1A,0xE8,0xD1,0x48,0xD5,0xE2,0x11,0x9F,0xFE,0xC4,0xBB,0xBE,0xE3};
 
+  TMapTypeEntry(const TMapTypeEntry&);
+  TMapTypeEntry& operator=(const TMapTypeEntry&);
   TMapTypeEntry() : keyTypePtr(0), valueTypePtr(0) {
   }
 
-  virtual ~TMapTypeEntry() throw() {}
-
+  virtual ~TMapTypeEntry() throw();
   TTypeEntryPtr keyTypePtr;
   TTypeEntryPtr valueTypePtr;
 
-  void __set_keyTypePtr(const TTypeEntryPtr val) {
-    keyTypePtr = val;
-  }
+  void __set_keyTypePtr(const TTypeEntryPtr val);
 
-  void __set_valueTypePtr(const TTypeEntryPtr val) {
-    valueTypePtr = val;
-  }
+  void __set_valueTypePtr(const TTypeEntryPtr val);
 
   bool operator == (const TMapTypeEntry & rhs) const
   {
@@ -402,6 +543,7 @@ class TMapTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TMapTypeEntry& obj);
 };
 
 void swap(TMapTypeEntry &a, TMapTypeEntry &b);
@@ -413,16 +555,15 @@ class TStructTypeEntry {
   static const char* ascii_fingerprint; // = "91F548CA159B4AB4291F5741AC161402";
   static const uint8_t binary_fingerprint[16]; // = {0x91,0xF5,0x48,0xCA,0x15,0x9B,0x4A,0xB4,0x29,0x1F,0x57,0x41,0xAC,0x16,0x14,0x02};
 
+  TStructTypeEntry(const TStructTypeEntry&);
+  TStructTypeEntry& operator=(const TStructTypeEntry&);
   TStructTypeEntry() {
   }
 
-  virtual ~TStructTypeEntry() throw() {}
-
+  virtual ~TStructTypeEntry() throw();
   std::map<std::string, TTypeEntryPtr>  nameToTypePtr;
 
-  void __set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val) {
-    nameToTypePtr = val;
-  }
+  void __set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val);
 
   bool operator == (const TStructTypeEntry & rhs) const
   {
@@ -439,6 +580,7 @@ class TStructTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TStructTypeEntry& obj);
 };
 
 void swap(TStructTypeEntry &a, TStructTypeEntry &b);
@@ -450,16 +592,15 @@ class TUnionTypeEntry {
   static const char* ascii_fingerprint; // = "91F548CA159B4AB4291F5741AC161402";
   static const uint8_t binary_fingerprint[16]; // = {0x91,0xF5,0x48,0xCA,0x15,0x9B,0x4A,0xB4,0x29,0x1F,0x57,0x41,0xAC,0x16,0x14,0x02};
 
+  TUnionTypeEntry(const TUnionTypeEntry&);
+  TUnionTypeEntry& operator=(const TUnionTypeEntry&);
   TUnionTypeEntry() {
   }
 
-  virtual ~TUnionTypeEntry() throw() {}
-
+  virtual ~TUnionTypeEntry() throw();
   std::map<std::string, TTypeEntryPtr>  nameToTypePtr;
 
-  void __set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val) {
-    nameToTypePtr = val;
-  }
+  void __set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val);
 
   bool operator == (const TUnionTypeEntry & rhs) const
   {
@@ -476,6 +617,7 @@ class TUnionTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TUnionTypeEntry& obj);
 };
 
 void swap(TUnionTypeEntry &a, TUnionTypeEntry &b);
@@ -487,16 +629,15 @@ class TUserDefinedTypeEntry {
   static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
   static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
+  TUserDefinedTypeEntry(const TUserDefinedTypeEntry&);
+  TUserDefinedTypeEntry& operator=(const TUserDefinedTypeEntry&);
   TUserDefinedTypeEntry() : typeClassName() {
   }
 
-  virtual ~TUserDefinedTypeEntry() throw() {}
-
+  virtual ~TUserDefinedTypeEntry() throw();
   std::string typeClassName;
 
-  void __set_typeClassName(const std::string& val) {
-    typeClassName = val;
-  }
+  void __set_typeClassName(const std::string& val);
 
   bool operator == (const TUserDefinedTypeEntry & rhs) const
   {
@@ -513,18 +654,19 @@ class TUserDefinedTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TUserDefinedTypeEntry& obj);
 };
 
 void swap(TUserDefinedTypeEntry &a, TUserDefinedTypeEntry &b);
 
 typedef struct _TTypeEntry__isset {
   _TTypeEntry__isset() : primitiveEntry(false), arrayEntry(false), mapEntry(false), structEntry(false), unionEntry(false), userDefinedTypeEntry(false) {}
-  bool primitiveEntry;
-  bool arrayEntry;
-  bool mapEntry;
-  bool structEntry;
-  bool unionEntry;
-  bool userDefinedTypeEntry;
+  bool primitiveEntry :1;
+  bool arrayEntry :1;
+  bool mapEntry :1;
+  bool structEntry :1;
+  bool unionEntry :1;
+  bool userDefinedTypeEntry :1;
 } _TTypeEntry__isset;
 
 class TTypeEntry {
@@ -533,11 +675,12 @@ class TTypeEntry {
   static const char* ascii_fingerprint; // = "2FE56D9097E325DAA7E933738C6D325F";
   static const uint8_t binary_fingerprint[16]; // = {0x2F,0xE5,0x6D,0x90,0x97,0xE3,0x25,0xDA,0xA7,0xE9,0x33,0x73,0x8C,0x6D,0x32,0x5F};
 
+  TTypeEntry(const TTypeEntry&);
+  TTypeEntry& operator=(const TTypeEntry&);
   TTypeEntry() {
   }
 
-  virtual ~TTypeEntry() throw() {}
-
+  virtual ~TTypeEntry() throw();
   TPrimitiveTypeEntry primitiveEntry;
   TArrayTypeEntry arrayEntry;
   TMapTypeEntry mapEntry;
@@ -547,29 +690,17 @@ class TTypeEntry {
 
   _TTypeEntry__isset __isset;
 
-  void __set_primitiveEntry(const TPrimitiveTypeEntry& val) {
-    primitiveEntry = val;
-  }
+  void __set_primitiveEntry(const TPrimitiveTypeEntry& val);
 
-  void __set_arrayEntry(const TArrayTypeEntry& val) {
-    arrayEntry = val;
-  }
+  void __set_arrayEntry(const TArrayTypeEntry& val);
 
-  void __set_mapEntry(const TMapTypeEntry& val) {
-    mapEntry = val;
-  }
+  void __set_mapEntry(const TMapTypeEntry& val);
 
-  void __set_structEntry(const TStructTypeEntry& val) {
-    structEntry = val;
-  }
+  void __set_structEntry(const TStructTypeEntry& val);
 
-  void __set_unionEntry(const TUnionTypeEntry& val) {
-    unionEntry = val;
-  }
+  void __set_unionEntry(const TUnionTypeEntry& val);
 
-  void __set_userDefinedTypeEntry(const TUserDefinedTypeEntry& val) {
-    userDefinedTypeEntry = val;
-  }
+  void __set_userDefinedTypeEntry(const TUserDefinedTypeEntry& val);
 
   bool operator == (const TTypeEntry & rhs) const
   {
@@ -596,6 +727,7 @@ class TTypeEntry {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TTypeEntry& obj);
 };
 
 void swap(TTypeEntry &a, TTypeEntry &b);
@@ -607,16 +739,15 @@ class TTypeDesc {
   static const char* ascii_fingerprint; // = "90B3C5A0B73419A84E85E0E48C452AA5";
   static const uint8_t binary_fingerprint[16]; // = {0x90,0xB3,0xC5,0xA0,0xB7,0x34,0x19,0xA8,0x4E,0x85,0xE0,0xE4,0x8C,0x45,0x2A,0xA5};
 
+  TTypeDesc(const TTypeDesc&);
+  TTypeDesc& operator=(const TTypeDesc&);
   TTypeDesc() {
   }
 
-  virtual ~TTypeDesc() throw() {}
-
+  virtual ~TTypeDesc() throw();
   std::vector<TTypeEntry>  types;
 
-  void __set_types(const std::vector<TTypeEntry> & val) {
-    types = val;
-  }
+  void __set_types(const std::vector<TTypeEntry> & val);
 
   bool operator == (const TTypeDesc & rhs) const
   {
@@ -633,13 +764,14 @@ class TTypeDesc {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TTypeDesc& obj);
 };
 
 void swap(TTypeDesc &a, TTypeDesc &b);
 
 typedef struct _TColumnDesc__isset {
   _TColumnDesc__isset() : comment(false) {}
-  bool comment;
+  bool comment :1;
 } _TColumnDesc__isset;
 
 class TColumnDesc {
@@ -648,11 +780,12 @@ class TColumnDesc {
   static const char* ascii_fingerprint; // = "EABED9009D5FCABFCA65612069F2A849";
   static const uint8_t binary_fingerprint[16]; // = {0xEA,0xBE,0xD9,0x00,0x9D,0x5F,0xCA,0xBF,0xCA,0x65,0x61,0x20,0x69,0xF2,0xA8,0x49};
 
+  TColumnDesc(const TColumnDesc&);
+  TColumnDesc& operator=(const TColumnDesc&);
   TColumnDesc() : columnName(), position(0), comment() {
   }
 
-  virtual ~TColumnDesc() throw() {}
-
+  virtual ~TColumnDesc() throw();
   std::string columnName;
   TTypeDesc typeDesc;
   int32_t position;
@@ -660,22 +793,13 @@ class TColumnDesc {
 
   _TColumnDesc__isset __isset;
 
-  void __set_columnName(const std::string& val) {
-    columnName = val;
-  }
+  void __set_columnName(const std::string& val);
 
-  void __set_typeDesc(const TTypeDesc& val) {
-    typeDesc = val;
-  }
+  void __set_typeDesc(const TTypeDesc& val);
 
-  void __set_position(const int32_t val) {
-    position = val;
-  }
+  void __set_position(const int32_t val);
 
-  void __set_comment(const std::string& val) {
-    comment = val;
-    __isset.comment = true;
-  }
+  void __set_comment(const std::string& val);
 
   bool operator == (const TColumnDesc & rhs) const
   {
@@ -700,6 +824,7 @@ class TColumnDesc {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TColumnDesc& obj);
 };
 
 void swap(TColumnDesc &a, TColumnDesc &b);
@@ -711,16 +836,15 @@ class TTableSchema {
   static const char* ascii_fingerprint; // = "7A1811E49313E5977107FC667B20E39D";
   static const uint8_t binary_fingerprint[16]; // = {0x7A,0x18,0x11,0xE4,0x93,0x13,0xE5,0x97,0x71,0x07,0xFC,0x66,0x7B,0x20,0xE3,0x9D};
 
+  TTableSchema(const TTableSchema&);
+  TTableSchema& operator=(const TTableSchema&);
   TTableSchema() {
   }
 
-  virtual ~TTableSchema() throw() {}
-
+  virtual ~TTableSchema() throw();
   std::vector<TColumnDesc>  columns;
 
-  void __set_columns(const std::vector<TColumnDesc> & val) {
-    columns = val;
-  }
+  void __set_columns(const std::vector<TColumnDesc> & val);
 
   bool operator == (const TTableSchema & rhs) const
   {
@@ -737,13 +861,14 @@ class TTableSchema {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TTableSchema& obj);
 };
 
 void swap(TTableSchema &a, TTableSchema &b);
 
 typedef struct _TBoolValue__isset {
   _TBoolValue__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TBoolValue__isset;
 
 class TBoolValue {
@@ -752,19 +877,17 @@ class TBoolValue {
   static const char* ascii_fingerprint; // = "BF054652DEF86253C2BEE7D947F167DD";
   static const uint8_t binary_fingerprint[16]; // = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
+  TBoolValue(const TBoolValue&);
+  TBoolValue& operator=(const TBoolValue&);
   TBoolValue() : value(0) {
   }
 
-  virtual ~TBoolValue() throw() {}
-
+  virtual ~TBoolValue() throw();
   bool value;
 
   _TBoolValue__isset __isset;
 
-  void __set_value(const bool val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const bool val);
 
   bool operator == (const TBoolValue & rhs) const
   {
@@ -783,13 +906,14 @@ class TBoolValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TBoolValue& obj);
 };
 
 void swap(TBoolValue &a, TBoolValue &b);
 
 typedef struct _TByteValue__isset {
   _TByteValue__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TByteValue__isset;
 
 class TByteValue {
@@ -798,19 +922,17 @@ class TByteValue {
   static const char* ascii_fingerprint; // = "9C15298ACB5D04AEA9B52D5DDE6F9208";
   static const uint8_t binary_fingerprint[16]; // = {0x9C,0x15,0x29,0x8A,0xCB,0x5D,0x04,0xAE,0xA9,0xB5,0x2D,0x5D,0xDE,0x6F,0x92,0x08};
 
+  TByteValue(const TByteValue&);
+  TByteValue& operator=(const TByteValue&);
   TByteValue() : value(0) {
   }
 
-  virtual ~TByteValue() throw() {}
-
+  virtual ~TByteValue() throw();
   int8_t value;
 
   _TByteValue__isset __isset;
 
-  void __set_value(const int8_t val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const int8_t val);
 
   bool operator == (const TByteValue & rhs) const
   {
@@ -829,13 +951,14 @@ class TByteValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TByteValue& obj);
 };
 
 void swap(TByteValue &a, TByteValue &b);
 
 typedef struct _TI16Value__isset {
   _TI16Value__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TI16Value__isset;
 
 class TI16Value {
@@ -844,19 +967,17 @@ class TI16Value {
   static const char* ascii_fingerprint; // = "5DAC9C51C7E1106BF936FC71860BE9D5";
   static const uint8_t binary_fingerprint[16]; // = {0x5D,0xAC,0x9C,0x51,0xC7,0xE1,0x10,0x6B,0xF9,0x36,0xFC,0x71,0x86,0x0B,0xE9,0xD5};
 
+  TI16Value(const TI16Value&);
+  TI16Value& operator=(const TI16Value&);
   TI16Value() : value(0) {
   }
 
-  virtual ~TI16Value() throw() {}
-
+  virtual ~TI16Value() throw();
   int16_t value;
 
   _TI16Value__isset __isset;
 
-  void __set_value(const int16_t val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const int16_t val);
 
   bool operator == (const TI16Value & rhs) const
   {
@@ -875,13 +996,14 @@ class TI16Value {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI16Value& obj);
 };
 
 void swap(TI16Value &a, TI16Value &b);
 
 typedef struct _TI32Value__isset {
   _TI32Value__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TI32Value__isset;
 
 class TI32Value {
@@ -890,19 +1012,17 @@ class TI32Value {
   static const char* ascii_fingerprint; // = "E7A96B151330359E84C0A3AC91BCBACD";
   static const uint8_t binary_fingerprint[16]; // = {0xE7,0xA9,0x6B,0x15,0x13,0x30,0x35,0x9E,0x84,0xC0,0xA3,0xAC,0x91,0xBC,0xBA,0xCD};
 
+  TI32Value(const TI32Value&);
+  TI32Value& operator=(const TI32Value&);
   TI32Value() : value(0) {
   }
 
-  virtual ~TI32Value() throw() {}
-
+  virtual ~TI32Value() throw();
   int32_t value;
 
   _TI32Value__isset __isset;
 
-  void __set_value(const int32_t val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const int32_t val);
 
   bool operator == (const TI32Value & rhs) const
   {
@@ -921,13 +1041,14 @@ class TI32Value {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI32Value& obj);
 };
 
 void swap(TI32Value &a, TI32Value &b);
 
 typedef struct _TI64Value__isset {
   _TI64Value__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TI64Value__isset;
 
 class TI64Value {
@@ -936,19 +1057,17 @@ class TI64Value {
   static const char* ascii_fingerprint; // = "148F3AAAC1D9859963D5E800D187BF26";
   static const uint8_t binary_fingerprint[16]; // = {0x14,0x8F,0x3A,0xAA,0xC1,0xD9,0x85,0x99,0x63,0xD5,0xE8,0x00,0xD1,0x87,0xBF,0x26};
 
+  TI64Value(const TI64Value&);
+  TI64Value& operator=(const TI64Value&);
   TI64Value() : value(0) {
   }
 
-  virtual ~TI64Value() throw() {}
-
+  virtual ~TI64Value() throw();
   int64_t value;
 
   _TI64Value__isset __isset;
 
-  void __set_value(const int64_t val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const int64_t val);
 
   bool operator == (const TI64Value & rhs) const
   {
@@ -967,13 +1086,14 @@ class TI64Value {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI64Value& obj);
 };
 
 void swap(TI64Value &a, TI64Value &b);
 
 typedef struct _TDoubleValue__isset {
   _TDoubleValue__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TDoubleValue__isset;
 
 class TDoubleValue {
@@ -982,19 +1102,17 @@ class TDoubleValue {
   static const char* ascii_fingerprint; // = "3586E570A474C4A8603B4FF74903B3A6";
   static const uint8_t binary_fingerprint[16]; // = {0x35,0x86,0xE5,0x70,0xA4,0x74,0xC4,0xA8,0x60,0x3B,0x4F,0xF7,0x49,0x03,0xB3,0xA6};
 
+  TDoubleValue(const TDoubleValue&);
+  TDoubleValue& operator=(const TDoubleValue&);
   TDoubleValue() : value(0) {
   }
 
-  virtual ~TDoubleValue() throw() {}
-
+  virtual ~TDoubleValue() throw();
   double value;
 
   _TDoubleValue__isset __isset;
 
-  void __set_value(const double val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const double val);
 
   bool operator == (const TDoubleValue & rhs) const
   {
@@ -1013,13 +1131,14 @@ class TDoubleValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TDoubleValue& obj);
 };
 
 void swap(TDoubleValue &a, TDoubleValue &b);
 
 typedef struct _TStringValue__isset {
   _TStringValue__isset() : value(false) {}
-  bool value;
+  bool value :1;
 } _TStringValue__isset;
 
 class TStringValue {
@@ -1028,19 +1147,17 @@ class TStringValue {
   static const char* ascii_fingerprint; // = "66E694018C17E5B65A59AE8F55CCA3CD";
   static const uint8_t binary_fingerprint[16]; // = {0x66,0xE6,0x94,0x01,0x8C,0x17,0xE5,0xB6,0x5A,0x59,0xAE,0x8F,0x55,0xCC,0xA3,0xCD};
 
+  TStringValue(const TStringValue&);
+  TStringValue& operator=(const TStringValue&);
   TStringValue() : value() {
   }
 
-  virtual ~TStringValue() throw() {}
-
+  virtual ~TStringValue() throw();
   std::string value;
 
   _TStringValue__isset __isset;
 
-  void __set_value(const std::string& val) {
-    value = val;
-    __isset.value = true;
-  }
+  void __set_value(const std::string& val);
 
   bool operator == (const TStringValue & rhs) const
   {
@@ -1059,19 +1176,20 @@ class TStringValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TStringValue& obj);
 };
 
 void swap(TStringValue &a, TStringValue &b);
 
 typedef struct _TColumnValue__isset {
   _TColumnValue__isset() : boolVal(false), byteVal(false), i16Val(false), i32Val(false), i64Val(false), doubleVal(false), stringVal(false) {}
-  bool boolVal;
-  bool byteVal;
-  bool i16Val;
-  bool i32Val;
-  bool i64Val;
-  bool doubleVal;
-  bool stringVal;
+  bool boolVal :1;
+  bool byteVal :1;
+  bool i16Val :1;
+  bool i32Val :1;
+  bool i64Val :1;
+  bool doubleVal :1;
+  bool stringVal :1;
 } _TColumnValue__isset;
 
 class TColumnValue {
@@ -1080,11 +1198,12 @@ class TColumnValue {
   static const char* ascii_fingerprint; // = "C2DDD988447EA7999A8285AA38AAE9AD";
   static const uint8_t binary_fingerprint[16]; // = {0xC2,0xDD,0xD9,0x88,0x44,0x7E,0xA7,0x99,0x9A,0x82,0x85,0xAA,0x38,0xAA,0xE9,0xAD};
 
+  TColumnValue(const TColumnValue&);
+  TColumnValue& operator=(const TColumnValue&);
   TColumnValue() {
   }
 
-  virtual ~TColumnValue() throw() {}
-
+  virtual ~TColumnValue() throw();
   TBoolValue boolVal;
   TByteValue byteVal;
   TI16Value i16Val;
@@ -1095,33 +1214,19 @@ class TColumnValue {
 
   _TColumnValue__isset __isset;
 
-  void __set_boolVal(const TBoolValue& val) {
-    boolVal = val;
-  }
+  void __set_boolVal(const TBoolValue& val);
 
-  void __set_byteVal(const TByteValue& val) {
-    byteVal = val;
-  }
+  void __set_byteVal(const TByteValue& val);
 
-  void __set_i16Val(const TI16Value& val) {
-    i16Val = val;
-  }
+  void __set_i16Val(const TI16Value& val);
 
-  void __set_i32Val(const TI32Value& val) {
-    i32Val = val;
-  }
+  void __set_i32Val(const TI32Value& val);
 
-  void __set_i64Val(const TI64Value& val) {
-    i64Val = val;
-  }
+  void __set_i64Val(const TI64Value& val);
 
-  void __set_doubleVal(const TDoubleValue& val) {
-    doubleVal = val;
-  }
+  void __set_doubleVal(const TDoubleValue& val);
 
-  void __set_stringVal(const TStringValue& val) {
-    stringVal = val;
-  }
+  void __set_stringVal(const TStringValue& val);
 
   bool operator == (const TColumnValue & rhs) const
   {
@@ -1150,6 +1255,7 @@ class TColumnValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TColumnValue& obj);
 };
 
 void swap(TColumnValue &a, TColumnValue &b);
@@ -1161,16 +1267,15 @@ class TRow {
   static const char* ascii_fingerprint; // = "E73FD1FCA0CA58A669FC3E02FB68D534";
   static const uint8_t binary_fingerprint[16]; // = {0xE7,0x3F,0xD1,0xFC,0xA0,0xCA,0x58,0xA6,0x69,0xFC,0x3E,0x02,0xFB,0x68,0xD5,0x34};
 
+  TRow(const TRow&);
+  TRow& operator=(const TRow&);
   TRow() {
   }
 
-  virtual ~TRow() throw() {}
-
+  virtual ~TRow() throw();
   std::vector<TColumnValue>  colVals;
 
-  void __set_colVals(const std::vector<TColumnValue> & val) {
-    colVals = val;
-  }
+  void __set_colVals(const std::vector<TColumnValue> & val);
 
   bool operator == (const TRow & rhs) const
   {
@@ -1187,6 +1292,7 @@ class TRow {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TRow& obj);
 };
 
 void swap(TRow &a, TRow &b);
@@ -1198,21 +1304,18 @@ class TBoolColumn {
   static const char* ascii_fingerprint; // = "F9058324D96DB7F974D8ACDC01C54219";
   static const uint8_t binary_fingerprint[16]; // = {0xF9,0x05,0x83,0x24,0xD9,0x6D,0xB7,0xF9,0x74,0xD8,0xAC,0xDC,0x01,0xC5,0x42,0x19};
 
+  TBoolColumn(const TBoolColumn&);
+  TBoolColumn& operator=(const TBoolColumn&);
   TBoolColumn() : nulls() {
   }
 
-  virtual ~TBoolColumn() throw() {}
-
+  virtual ~TBoolColumn() throw();
   std::vector<bool>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<bool> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<bool> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TBoolColumn & rhs) const
   {
@@ -1231,6 +1334,7 @@ class TBoolColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TBoolColumn& obj);
 };
 
 void swap(TBoolColumn &a, TBoolColumn &b);
@@ -1242,21 +1346,18 @@ class TByteColumn {
   static const char* ascii_fingerprint; // = "1CB300106BAA463A70BB2A2395900F48";
   static const uint8_t binary_fingerprint[16]; // = {0x1C,0xB3,0x00,0x10,0x6B,0xAA,0x46,0x3A,0x70,0xBB,0x2A,0x23,0x95,0x90,0x0F,0x48};
 
+  TByteColumn(const TByteColumn&);
+  TByteColumn& operator=(const TByteColumn&);
   TByteColumn() : nulls() {
   }
 
-  virtual ~TByteColumn() throw() {}
-
+  virtual ~TByteColumn() throw();
   std::vector<int8_t>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<int8_t> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<int8_t> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TByteColumn & rhs) const
   {
@@ -1275,6 +1376,7 @@ class TByteColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TByteColumn& obj);
 };
 
 void swap(TByteColumn &a, TByteColumn &b);
@@ -1286,21 +1388,18 @@ class TI16Column {
   static const char* ascii_fingerprint; // = "6574CDB1F121C8DB47FB257A3F104BDB";
   static const uint8_t binary_fingerprint[16]; // = {0x65,0x74,0xCD,0xB1,0xF1,0x21,0xC8,0xDB,0x47,0xFB,0x25,0x7A,0x3F,0x10,0x4B,0xDB};
 
+  TI16Column(const TI16Column&);
+  TI16Column& operator=(const TI16Column&);
   TI16Column() : nulls() {
   }
 
-  virtual ~TI16Column() throw() {}
-
+  virtual ~TI16Column() throw();
   std::vector<int16_t>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<int16_t> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<int16_t> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TI16Column & rhs) const
   {
@@ -1319,6 +1418,7 @@ class TI16Column {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI16Column& obj);
 };
 
 void swap(TI16Column &a, TI16Column &b);
@@ -1330,21 +1430,18 @@ class TI32Column {
   static const char* ascii_fingerprint; // = "CCCCE89C7E9DA10280F5663700677313";
   static const uint8_t binary_fingerprint[16]; // = {0xCC,0xCC,0xE8,0x9C,0x7E,0x9D,0xA1,0x02,0x80,0xF5,0x66,0x37,0x00,0x67,0x73,0x13};
 
+  TI32Column(const TI32Column&);
+  TI32Column& operator=(const TI32Column&);
   TI32Column() : nulls() {
   }
 
-  virtual ~TI32Column() throw() {}
-
+  virtual ~TI32Column() throw();
   std::vector<int32_t>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<int32_t> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<int32_t> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TI32Column & rhs) const
   {
@@ -1363,6 +1460,7 @@ class TI32Column {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI32Column& obj);
 };
 
 void swap(TI32Column &a, TI32Column &b);
@@ -1374,21 +1472,18 @@ class TI64Column {
   static const char* ascii_fingerprint; // = "925353917FC0AF87976A2338011F5A31";
   static const uint8_t binary_fingerprint[16]; // = {0x92,0x53,0x53,0x91,0x7F,0xC0,0xAF,0x87,0x97,0x6A,0x23,0x38,0x01,0x1F,0x5A,0x31};
 
+  TI64Column(const TI64Column&);
+  TI64Column& operator=(const TI64Column&);
   TI64Column() : nulls() {
   }
 
-  virtual ~TI64Column() throw() {}
-
+  virtual ~TI64Column() throw();
   std::vector<int64_t>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<int64_t> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<int64_t> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TI64Column & rhs) const
   {
@@ -1407,6 +1502,7 @@ class TI64Column {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TI64Column& obj);
 };
 
 void swap(TI64Column &a, TI64Column &b);
@@ -1418,21 +1514,18 @@ class TDoubleColumn {
   static const char* ascii_fingerprint; // = "8FF1C050A8D7FD247AEB23CD71539C09";
   static const uint8_t binary_fingerprint[16]; // = {0x8F,0xF1,0xC0,0x50,0xA8,0xD7,0xFD,0x24,0x7A,0xEB,0x23,0xCD,0x71,0x53,0x9C,0x09};
 
+  TDoubleColumn(const TDoubleColumn&);
+  TDoubleColumn& operator=(const TDoubleColumn&);
   TDoubleColumn() : nulls() {
   }
 
-  virtual ~TDoubleColumn() throw() {}
-
+  virtual ~TDoubleColumn() throw();
   std::vector<double>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<double> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<double> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TDoubleColumn & rhs) const
   {
@@ -1451,6 +1544,7 @@ class TDoubleColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TDoubleColumn& obj);
 };
 
 void swap(TDoubleColumn &a, TDoubleColumn &b);
@@ -1462,21 +1556,18 @@ class TStringColumn {
   static const char* ascii_fingerprint; // = "BE556BF7091B2DABBA1863D5E458B15F";
   static const uint8_t binary_fingerprint[16]; // = {0xBE,0x55,0x6B,0xF7,0x09,0x1B,0x2D,0xAB,0xBA,0x18,0x63,0xD5,0xE4,0x58,0xB1,0x5F};
 
+  TStringColumn(const TStringColumn&);
+  TStringColumn& operator=(const TStringColumn&);
   TStringColumn() : nulls() {
   }
 
-  virtual ~TStringColumn() throw() {}
-
+  virtual ~TStringColumn() throw();
   std::vector<std::string>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<std::string> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<std::string> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TStringColumn & rhs) const
   {
@@ -1495,6 +1586,7 @@ class TStringColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TStringColumn& obj);
 };
 
 void swap(TStringColumn &a, TStringColumn &b);
@@ -1506,21 +1598,18 @@ class TBinaryColumn {
   static const char* ascii_fingerprint; // = "BE556BF7091B2DABBA1863D5E458B15F";
   static const uint8_t binary_fingerprint[16]; // = {0xBE,0x55,0x6B,0xF7,0x09,0x1B,0x2D,0xAB,0xBA,0x18,0x63,0xD5,0xE4,0x58,0xB1,0x5F};
 
+  TBinaryColumn(const TBinaryColumn&);
+  TBinaryColumn& operator=(const TBinaryColumn&);
   TBinaryColumn() : nulls() {
   }
 
-  virtual ~TBinaryColumn() throw() {}
-
+  virtual ~TBinaryColumn() throw();
   std::vector<std::string>  values;
   std::string nulls;
 
-  void __set_values(const std::vector<std::string> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<std::string> & val);
 
-  void __set_nulls(const std::string& val) {
-    nulls = val;
-  }
+  void __set_nulls(const std::string& val);
 
   bool operator == (const TBinaryColumn & rhs) const
   {
@@ -1539,20 +1628,21 @@ class TBinaryColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TBinaryColumn& obj);
 };
 
 void swap(TBinaryColumn &a, TBinaryColumn &b);
 
 typedef struct _TColumn__isset {
   _TColumn__isset() : boolVal(false), byteVal(false), i16Val(false), i32Val(false), i64Val(false), doubleVal(false), stringVal(false), binaryVal(false) {}
-  bool boolVal;
-  bool byteVal;
-  bool i16Val;
-  bool i32Val;
-  bool i64Val;
-  bool doubleVal;
-  bool stringVal;
-  bool binaryVal;
+  bool boolVal :1;
+  bool byteVal :1;
+  bool i16Val :1;
+  bool i32Val :1;
+  bool i64Val :1;
+  bool doubleVal :1;
+  bool stringVal :1;
+  bool binaryVal :1;
 } _TColumn__isset;
 
 class TColumn {
@@ -1561,11 +1651,12 @@ class TColumn {
   static const char* ascii_fingerprint; // = "E6ADD10B4CDDE61A19E8878CC7039A17";
   static const uint8_t binary_fingerprint[16]; // = {0xE6,0xAD,0xD1,0x0B,0x4C,0xDD,0xE6,0x1A,0x19,0xE8,0x87,0x8C,0xC7,0x03,0x9A,0x17};
 
+  TColumn(const TColumn&);
+  TColumn& operator=(const TColumn&);
   TColumn() {
   }
 
-  virtual ~TColumn() throw() {}
-
+  virtual ~TColumn() throw();
   TBoolColumn boolVal;
   TByteColumn byteVal;
   TI16Column i16Val;
@@ -1577,37 +1668,21 @@ class TColumn {
 
   _TColumn__isset __isset;
 
-  void __set_boolVal(const TBoolColumn& val) {
-    boolVal = val;
-  }
+  void __set_boolVal(const TBoolColumn& val);
 
-  void __set_byteVal(const TByteColumn& val) {
-    byteVal = val;
-  }
+  void __set_byteVal(const TByteColumn& val);
 
-  void __set_i16Val(const TI16Column& val) {
-    i16Val = val;
-  }
+  void __set_i16Val(const TI16Column& val);
 
-  void __set_i32Val(const TI32Column& val) {
-    i32Val = val;
-  }
+  void __set_i32Val(const TI32Column& val);
 
-  void __set_i64Val(const TI64Column& val) {
-    i64Val = val;
-  }
+  void __set_i64Val(const TI64Column& val);
 
-  void __set_doubleVal(const TDoubleColumn& val) {
-    doubleVal = val;
-  }
+  void __set_doubleVal(const TDoubleColumn& val);
 
-  void __set_stringVal(const TStringColumn& val) {
-    stringVal = val;
-  }
+  void __set_stringVal(const TStringColumn& val);
 
-  void __set_binaryVal(const TBinaryColumn& val) {
-    binaryVal = val;
-  }
+  void __set_binaryVal(const TBinaryColumn& val);
 
   bool operator == (const TColumn & rhs) const
   {
@@ -1638,13 +1713,14 @@ class TColumn {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TColumn& obj);
 };
 
 void swap(TColumn &a, TColumn &b);
 
 typedef struct _TRowSet__isset {
   _TRowSet__isset() : columns(false) {}
-  bool columns;
+  bool columns :1;
 } _TRowSet__isset;
 
 class TRowSet {
@@ -1653,29 +1729,23 @@ class TRowSet {
   static const char* ascii_fingerprint; // = "46DA30A870489C7A58105AE0080DAEBF";
   static const uint8_t binary_fingerprint[16]; // = {0x46,0xDA,0x30,0xA8,0x70,0x48,0x9C,0x7A,0x58,0x10,0x5A,0xE0,0x08,0x0D,0xAE,0xBF};
 
+  TRowSet(const TRowSet&);
+  TRowSet& operator=(const TRowSet&);
   TRowSet() : startRowOffset(0) {
   }
 
-  virtual ~TRowSet() throw() {}
-
+  virtual ~TRowSet() throw();
   int64_t startRowOffset;
   std::vector<TRow>  rows;
   std::vector<TColumn>  columns;
 
   _TRowSet__isset __isset;
 
-  void __set_startRowOffset(const int64_t val) {
-    startRowOffset = val;
-  }
+  void __set_startRowOffset(const int64_t val);
 
-  void __set_rows(const std::vector<TRow> & val) {
-    rows = val;
-  }
+  void __set_rows(const std::vector<TRow> & val);
 
-  void __set_columns(const std::vector<TColumn> & val) {
-    columns = val;
-    __isset.columns = true;
-  }
+  void __set_columns(const std::vector<TColumn> & val);
 
   bool operator == (const TRowSet & rhs) const
   {
@@ -1698,16 +1768,17 @@ class TRowSet {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TRowSet& obj);
 };
 
 void swap(TRowSet &a, TRowSet &b);
 
 typedef struct _TStatus__isset {
   _TStatus__isset() : infoMessages(false), sqlState(false), errorCode(false), errorMessage(false) {}
-  bool infoMessages;
-  bool sqlState;
-  bool errorCode;
-  bool errorMessage;
+  bool infoMessages :1;
+  bool sqlState :1;
+  bool errorCode :1;
+  bool errorMessage :1;
 } _TStatus__isset;
 
 class TStatus {
@@ -1716,11 +1787,12 @@ class TStatus {
   static const char* ascii_fingerprint; // = "D5DEF49634A59C615C1B3A6F7D0DADB5";
   static const uint8_t binary_fingerprint[16]; // = {0xD5,0xDE,0xF4,0x96,0x34,0xA5,0x9C,0x61,0x5C,0x1B,0x3A,0x6F,0x7D,0x0D,0xAD,0xB5};
 
+  TStatus(const TStatus&);
+  TStatus& operator=(const TStatus&);
   TStatus() : statusCode((TStatusCode::type)0), sqlState(), errorCode(0), errorMessage() {
   }
 
-  virtual ~TStatus() throw() {}
-
+  virtual ~TStatus() throw();
   TStatusCode::type statusCode;
   std::vector<std::string>  infoMessages;
   std::string sqlState;
@@ -1729,29 +1801,15 @@ class TStatus {
 
   _TStatus__isset __isset;
 
-  void __set_statusCode(const TStatusCode::type val) {
-    statusCode = val;
-  }
+  void __set_statusCode(const TStatusCode::type val);
 
-  void __set_infoMessages(const std::vector<std::string> & val) {
-    infoMessages = val;
-    __isset.infoMessages = true;
-  }
+  void __set_infoMessages(const std::vector<std::string> & val);
 
-  void __set_sqlState(const std::string& val) {
-    sqlState = val;
-    __isset.sqlState = true;
-  }
+  void __set_sqlState(const std::string& val);
 
-  void __set_errorCode(const int32_t val) {
-    errorCode = val;
-    __isset.errorCode = true;
-  }
+  void __set_errorCode(const int32_t val);
 
-  void __set_errorMessage(const std::string& val) {
-    errorMessage = val;
-    __isset.errorMessage = true;
-  }
+  void __set_errorMessage(const std::string& val);
 
   bool operator == (const TStatus & rhs) const
   {
@@ -1784,6 +1842,7 @@ class TStatus {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TStatus& obj);
 };
 
 void swap(TStatus &a, TStatus &b);
@@ -1795,21 +1854,18 @@ class THandleIdentifier {
   static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
   static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
+  THandleIdentifier(const THandleIdentifier&);
+  THandleIdentifier& operator=(const THandleIdentifier&);
   THandleIdentifier() : guid(), secret() {
   }
 
-  virtual ~THandleIdentifier() throw() {}
-
+  virtual ~THandleIdentifier() throw();
   std::string guid;
   std::string secret;
 
-  void __set_guid(const std::string& val) {
-    guid = val;
-  }
+  void __set_guid(const std::string& val);
 
-  void __set_secret(const std::string& val) {
-    secret = val;
-  }
+  void __set_secret(const std::string& val);
 
   bool operator == (const THandleIdentifier & rhs) const
   {
@@ -1828,6 +1884,7 @@ class THandleIdentifier {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const THandleIdentifier& obj);
 };
 
 void swap(THandleIdentifier &a, THandleIdentifier &b);
@@ -1839,16 +1896,15 @@ class TSessionHandle {
   static const char* ascii_fingerprint; // = "A756D3DBE614FB13F70BF7F7B6EB3D73";
   static const uint8_t binary_fingerprint[16]; // = {0xA7,0x56,0xD3,0xDB,0xE6,0x14,0xFB,0x13,0xF7,0x0B,0xF7,0xF7,0xB6,0xEB,0x3D,0x73};
 
+  TSessionHandle(const TSessionHandle&);
+  TSessionHandle& operator=(const TSessionHandle&);
   TSessionHandle() {
   }
 
-  virtual ~TSessionHandle() throw() {}
-
+  virtual ~TSessionHandle() throw();
   THandleIdentifier sessionId;
 
-  void __set_sessionId(const THandleIdentifier& val) {
-    sessionId = val;
-  }
+  void __set_sessionId(const THandleIdentifier& val);
 
   bool operator == (const TSessionHandle & rhs) const
   {
@@ -1865,13 +1921,14 @@ class TSessionHandle {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TSessionHandle& obj);
 };
 
 void swap(TSessionHandle &a, TSessionHandle &b);
 
 typedef struct _TOperationHandle__isset {
   _TOperationHandle__isset() : modifiedRowCount(false) {}
-  bool modifiedRowCount;
+  bool modifiedRowCount :1;
 } _TOperationHandle__isset;
 
 class TOperationHandle {
@@ -1880,11 +1937,12 @@ class TOperationHandle {
   static const char* ascii_fingerprint; // = "29FD80F4F96804A30FCC59C23D2E5349";
   static const uint8_t binary_fingerprint[16]; // = {0x29,0xFD,0x80,0xF4,0xF9,0x68,0x04,0xA3,0x0F,0xCC,0x59,0xC2,0x3D,0x2E,0x53,0x49};
 
+  TOperationHandle(const TOperationHandle&);
+  TOperationHandle& operator=(const TOperationHandle&);
   TOperationHandle() : operationType((TOperationType::type)0), hasResultSet(0), modifiedRowCount(0) {
   }
 
-  virtual ~TOperationHandle() throw() {}
-
+  virtual ~TOperationHandle() throw();
   THandleIdentifier operationId;
   TOperationType::type operationType;
   bool hasResultSet;
@@ -1892,22 +1950,13 @@ class TOperationHandle {
 
   _TOperationHandle__isset __isset;
 
-  void __set_operationId(const THandleIdentifier& val) {
-    operationId = val;
-  }
+  void __set_operationId(const THandleIdentifier& val);
 
-  void __set_operationType(const TOperationType::type val) {
-    operationType = val;
-  }
+  void __set_operationType(const TOperationType::type val);
 
-  void __set_hasResultSet(const bool val) {
-    hasResultSet = val;
-  }
+  void __set_hasResultSet(const bool val);
 
-  void __set_modifiedRowCount(const double val) {
-    modifiedRowCount = val;
-    __isset.modifiedRowCount = true;
-  }
+  void __set_modifiedRowCount(const double val);
 
   bool operator == (const TOperationHandle & rhs) const
   {
@@ -1932,15 +1981,16 @@ class TOperationHandle {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TOperationHandle& obj);
 };
 
 void swap(TOperationHandle &a, TOperationHandle &b);
 
 typedef struct _TOpenSessionReq__isset {
   _TOpenSessionReq__isset() : username(false), password(false), configuration(false) {}
-  bool username;
-  bool password;
-  bool configuration;
+  bool username :1;
+  bool password :1;
+  bool configuration :1;
 } _TOpenSessionReq__isset;
 
 class TOpenSessionReq {
@@ -1949,13 +1999,14 @@ class TOpenSessionReq {
   static const char* ascii_fingerprint; // = "C8FD0F306A16C16BDA7B57F58BFAE5B2";
   static const uint8_t binary_fingerprint[16]; // = {0xC8,0xFD,0x0F,0x30,0x6A,0x16,0xC1,0x6B,0xDA,0x7B,0x57,0xF5,0x8B,0xFA,0xE5,0xB2};
 
+  TOpenSessionReq(const TOpenSessionReq&);
+  TOpenSessionReq& operator=(const TOpenSessionReq&);
   TOpenSessionReq() : client_protocol((TProtocolVersion::type)7), username(), password() {
     client_protocol = (TProtocolVersion::type)7;
 
   }
 
-  virtual ~TOpenSessionReq() throw() {}
-
+  virtual ~TOpenSessionReq() throw();
   TProtocolVersion::type client_protocol;
   std::string username;
   std::string password;
@@ -1963,24 +2014,13 @@ class TOpenSessionReq {
 
   _TOpenSessionReq__isset __isset;
 
-  void __set_client_protocol(const TProtocolVersion::type val) {
-    client_protocol = val;
-  }
+  void __set_client_protocol(const TProtocolVersion::type val);
 
-  void __set_username(const std::string& val) {
-    username = val;
-    __isset.username = true;
-  }
+  void __set_username(const std::string& val);
 
-  void __set_password(const std::string& val) {
-    password = val;
-    __isset.password = true;
-  }
+  void __set_password(const std::string& val);
 
-  void __set_configuration(const std::map<std::string, std::string> & val) {
-    configuration = val;
-    __isset.configuration = true;
-  }
+  void __set_configuration(const std::map<std::string, std::string> & val);
 
   bool operator == (const TOpenSessionReq & rhs) const
   {
@@ -2009,14 +2049,15 @@ class TOpenSessionReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TOpenSessionReq& obj);
 };
 
 void swap(TOpenSessionReq &a, TOpenSessionReq &b);
 
 typedef struct _TOpenSessionResp__isset {
   _TOpenSessionResp__isset() : sessionHandle(false), configuration(false) {}
-  bool sessionHandle;
-  bool configuration;
+  bool sessionHandle :1;
+  bool configuration :1;
 } _TOpenSessionResp__isset;
 
 class TOpenSessionResp {
@@ -2025,13 +2066,14 @@ class TOpenSessionResp {
   static const char* ascii_fingerprint; // = "CFE7D7F4E9EC671F2518ED74FEE9F163";
   static const uint8_t binary_fingerprint[16]; // = {0xCF,0xE7,0xD7,0xF4,0xE9,0xEC,0x67,0x1F,0x25,0x18,0xED,0x74,0xFE,0xE9,0xF1,0x63};
 
+  TOpenSessionResp(const TOpenSessionResp&);
+  TOpenSessionResp& operator=(const TOpenSessionResp&);
   TOpenSessionResp() : serverProtocolVersion((TProtocolVersion::type)7) {
     serverProtocolVersion = (TProtocolVersion::type)7;
 
   }
 
-  virtual ~TOpenSessionResp() throw() {}
-
+  virtual ~TOpenSessionResp() throw();
   TStatus status;
   TProtocolVersion::type serverProtocolVersion;
   TSessionHandle sessionHandle;
@@ -2039,23 +2081,13 @@ class TOpenSessionResp {
 
   _TOpenSessionResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_serverProtocolVersion(const TProtocolVersion::type val) {
-    serverProtocolVersion = val;
-  }
+  void __set_serverProtocolVersion(const TProtocolVersion::type val);
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-    __isset.sessionHandle = true;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_configuration(const std::map<std::string, std::string> & val) {
-    configuration = val;
-    __isset.configuration = true;
-  }
+  void __set_configuration(const std::map<std::string, std::string> & val);
 
   bool operator == (const TOpenSessionResp & rhs) const
   {
@@ -2082,6 +2114,7 @@ class TOpenSessionResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TOpenSessionResp& obj);
 };
 
 void swap(TOpenSessionResp &a, TOpenSessionResp &b);
@@ -2093,16 +2126,15 @@ class TCloseSessionReq {
   static const char* ascii_fingerprint; // = "82377107F8BD0526960537D5A112E6EF";
   static const uint8_t binary_fingerprint[16]; // = {0x82,0x37,0x71,0x07,0xF8,0xBD,0x05,0x26,0x96,0x05,0x37,0xD5,0xA1,0x12,0xE6,0xEF};
 
+  TCloseSessionReq(const TCloseSessionReq&);
+  TCloseSessionReq& operator=(const TCloseSessionReq&);
   TCloseSessionReq() {
   }
 
-  virtual ~TCloseSessionReq() throw() {}
-
+  virtual ~TCloseSessionReq() throw();
   TSessionHandle sessionHandle;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
   bool operator == (const TCloseSessionReq & rhs) const
   {
@@ -2119,6 +2151,7 @@ class TCloseSessionReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCloseSessionReq& obj);
 };
 
 void swap(TCloseSessionReq &a, TCloseSessionReq &b);
@@ -2130,16 +2163,15 @@ class TCloseSessionResp {
   static const char* ascii_fingerprint; // = "7142E89F09DC7C5F6FA916C7393F46C2";
   static const uint8_t binary_fingerprint[16]; // = {0x71,0x42,0xE8,0x9F,0x09,0xDC,0x7C,0x5F,0x6F,0xA9,0x16,0xC7,0x39,0x3F,0x46,0xC2};
 
+  TCloseSessionResp(const TCloseSessionResp&);
+  TCloseSessionResp& operator=(const TCloseSessionResp&);
   TCloseSessionResp() {
   }
 
-  virtual ~TCloseSessionResp() throw() {}
-
+  virtual ~TCloseSessionResp() throw();
   TStatus status;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
   bool operator == (const TCloseSessionResp & rhs) const
   {
@@ -2156,18 +2188,19 @@ class TCloseSessionResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TCloseSessionResp& obj);
 };
 
 void swap(TCloseSessionResp &a, TCloseSessionResp &b);
 
 typedef struct _TGetInfoValue__isset {
   _TGetInfoValue__isset() : stringValue(false), smallIntValue(false), integerBitmask(false), integerFlag(false), binaryValue(false), lenValue(false) {}
-  bool stringValue;
-  bool smallIntValue;
-  bool integerBitmask;
-  bool integerFlag;
-  bool binaryValue;
-  bool lenValue;
+  bool stringValue :1;
+  bool smallIntValue :1;
+  bool integerBitmask :1;
+  bool integerFlag :1;
+  bool binaryValue :1;
+  bool lenValue :1;
 } _TGetInfoValue__isset;
 
 class TGetInfoValue {
@@ -2176,11 +2209,12 @@ class TGetInfoValue {
   static const char* ascii_fingerprint; // = "057FED11279FD7248CFE73EE82ED579E";
   static const uint8_t binary_fingerprint[16]; // = {0x05,0x7F,0xED,0x11,0x27,0x9F,0xD7,0x24,0x8C,0xFE,0x73,0xEE,0x82,0xED,0x57,0x9E};
 
+  TGetInfoValue(const TGetInfoValue&);
+  TGetInfoValue& operator=(const TGetInfoValue&);
   TGetInfoValue() : stringValue(), smallIntValue(0), integerBitmask(0), integerFlag(0), binaryValue(0), lenValue(0) {
   }
 
-  virtual ~TGetInfoValue() throw() {}
-
+  virtual ~TGetInfoValue() throw();
   std::string stringValue;
   int16_t smallIntValue;
   int32_t integerBitmask;
@@ -2190,29 +2224,17 @@ class TGetInfoValue {
 
   _TGetInfoValue__isset __isset;
 
-  void __set_stringValue(const std::string& val) {
-    stringValue = val;
-  }
+  void __set_stringValue(const std::string& val);
 
-  void __set_smallIntValue(const int16_t val) {
-    smallIntValue = val;
-  }
+  void __set_smallIntValue(const int16_t val);
 
-  void __set_integerBitmask(const int32_t val) {
-    integerBitmask = val;
-  }
+  void __set_integerBitmask(const int32_t val);
 
-  void __set_integerFlag(const int32_t val) {
-    integerFlag = val;
-  }
+  void __set_integerFlag(const int32_t val);
 
-  void __set_binaryValue(const int32_t val) {
-    binaryValue = val;
-  }
+  void __set_binaryValue(const int32_t val);
 
-  void __set_lenValue(const int64_t val) {
-    lenValue = val;
-  }
+  void __set_lenValue(const int64_t val);
 
   bool operator == (const TGetInfoValue & rhs) const
   {
@@ -2239,6 +2261,7 @@ class TGetInfoValue {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetInfoValue& obj);
 };
 
 void swap(TGetInfoValue &a, TGetInfoValue &b);
@@ -2250,21 +2273,18 @@ class TGetInfoReq {
   static const char* ascii_fingerprint; // = "95675B1A0BADE5F7EDE323809DB679B2";
   static const uint8_t binary_fingerprint[16]; // = {0x95,0x67,0x5B,0x1A,0x0B,0xAD,0xE5,0xF7,0xED,0xE3,0x23,0x80,0x9D,0xB6,0x79,0xB2};
 
+  TGetInfoReq(const TGetInfoReq&);
+  TGetInfoReq& operator=(const TGetInfoReq&);
   TGetInfoReq() : infoType((TGetInfoType::type)0) {
   }
 
-  virtual ~TGetInfoReq() throw() {}
-
+  virtual ~TGetInfoReq() throw();
   TSessionHandle sessionHandle;
   TGetInfoType::type infoType;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_infoType(const TGetInfoType::type val) {
-    infoType = val;
-  }
+  void __set_infoType(const TGetInfoType::type val);
 
   bool operator == (const TGetInfoReq & rhs) const
   {
@@ -2283,6 +2303,7 @@ class TGetInfoReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetInfoReq& obj);
 };
 
 void swap(TGetInfoReq &a, TGetInfoReq &b);
@@ -2294,21 +2315,18 @@ class TGetInfoResp {
   static const char* ascii_fingerprint; // = "72AFA10A82728B51FDE91092012868DE";
   static const uint8_t binary_fingerprint[16]; // = {0x72,0xAF,0xA1,0x0A,0x82,0x72,0x8B,0x51,0xFD,0xE9,0x10,0x92,0x01,0x28,0x68,0xDE};
 
+  TGetInfoResp(const TGetInfoResp&);
+  TGetInfoResp& operator=(const TGetInfoResp&);
   TGetInfoResp() {
   }
 
-  virtual ~TGetInfoResp() throw() {}
-
+  virtual ~TGetInfoResp() throw();
   TStatus status;
   TGetInfoValue infoValue;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_infoValue(const TGetInfoValue& val) {
-    infoValue = val;
-  }
+  void __set_infoValue(const TGetInfoValue& val);
 
   bool operator == (const TGetInfoResp & rhs) const
   {
@@ -2327,14 +2345,15 @@ class TGetInfoResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetInfoResp& obj);
 };
 
 void swap(TGetInfoResp &a, TGetInfoResp &b);
 
 typedef struct _TExecuteStatementReq__isset {
   _TExecuteStatementReq__isset() : confOverlay(false), runAsync(true) {}
-  bool confOverlay;
-  bool runAsync;
+  bool confOverlay :1;
+  bool runAsync :1;
 } _TExecuteStatementReq__isset;
 
 class TExecuteStatementReq {
@@ -2343,11 +2362,12 @@ class TExecuteStatementReq {
   static const char* ascii_fingerprint; // = "FED75DB77E66D76EC1939A51FB0D96FA";
   static const uint8_t binary_fingerprint[16]; // = {0xFE,0xD7,0x5D,0xB7,0x7E,0x66,0xD7,0x6E,0xC1,0x93,0x9A,0x51,0xFB,0x0D,0x96,0xFA};
 
+  TExecuteStatementReq(const TExecuteStatementReq&);
+  TExecuteStatementReq& operator=(const TExecuteStatementReq&);
   TExecuteStatementReq() : statement(), runAsync(false) {
   }
 
-  virtual ~TExecuteStatementReq() throw() {}
-
+  virtual ~TExecuteStatementReq() throw();
   TSessionHandle sessionHandle;
   std::string statement;
   std::map<std::string, std::string>  confOverlay;
@@ -2355,23 +2375,13 @@ class TExecuteStatementReq {
 
   _TExecuteStatementReq__isset __isset;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_statement(const std::string& val) {
-    statement = val;
-  }
+  void __set_statement(const std::string& val);
 
-  void __set_confOverlay(const std::map<std::string, std::string> & val) {
-    confOverlay = val;
-    __isset.confOverlay = true;
-  }
+  void __set_confOverlay(const std::map<std::string, std::string> & val);
 
-  void __set_runAsync(const bool val) {
-    runAsync = val;
-    __isset.runAsync = true;
-  }
+  void __set_runAsync(const bool val);
 
   bool operator == (const TExecuteStatementReq & rhs) const
   {
@@ -2398,13 +2408,14 @@ class TExecuteStatementReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TExecuteStatementReq& obj);
 };
 
 void swap(TExecuteStatementReq &a, TExecuteStatementReq &b);
 
 typedef struct _TExecuteStatementResp__isset {
   _TExecuteStatementResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TExecuteStatementResp__isset;
 
 class TExecuteStatementResp {
@@ -2413,24 +2424,20 @@ class TExecuteStatementResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TExecuteStatementResp(const TExecuteStatementResp&);
+  TExecuteStatementResp& operator=(const TExecuteStatementResp&);
   TExecuteStatementResp() {
   }
 
-  virtual ~TExecuteStatementResp() throw() {}
-
+  virtual ~TExecuteStatementResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TExecuteStatementResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TExecuteStatementResp & rhs) const
   {
@@ -2451,6 +2458,7 @@ class TExecuteStatementResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TExecuteStatementResp& obj);
 };
 
 void swap(TExecuteStatementResp &a, TExecuteStatementResp &b);
@@ -2462,16 +2470,15 @@ class TGetTypeInfoReq {
   static const char* ascii_fingerprint; // = "82377107F8BD0526960537D5A112E6EF";
   static const uint8_t binary_fingerprint[16]; // = {0x82,0x37,0x71,0x07,0xF8,0xBD,0x05,0x26,0x96,0x05,0x37,0xD5,0xA1,0x12,0xE6,0xEF};
 
+  TGetTypeInfoReq(const TGetTypeInfoReq&);
+  TGetTypeInfoReq& operator=(const TGetTypeInfoReq&);
   TGetTypeInfoReq() {
   }
 
-  virtual ~TGetTypeInfoReq() throw() {}
-
+  virtual ~TGetTypeInfoReq() throw();
   TSessionHandle sessionHandle;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
   bool operator == (const TGetTypeInfoReq & rhs) const
   {
@@ -2488,13 +2495,14 @@ class TGetTypeInfoReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTypeInfoReq& obj);
 };
 
 void swap(TGetTypeInfoReq &a, TGetTypeInfoReq &b);
 
 typedef struct _TGetTypeInfoResp__isset {
   _TGetTypeInfoResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetTypeInfoResp__isset;
 
 class TGetTypeInfoResp {
@@ -2503,24 +2511,20 @@ class TGetTypeInfoResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetTypeInfoResp(const TGetTypeInfoResp&);
+  TGetTypeInfoResp& operator=(const TGetTypeInfoResp&);
   TGetTypeInfoResp() {
   }
 
-  virtual ~TGetTypeInfoResp() throw() {}
-
+  virtual ~TGetTypeInfoResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetTypeInfoResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetTypeInfoResp & rhs) const
   {
@@ -2541,6 +2545,7 @@ class TGetTypeInfoResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTypeInfoResp& obj);
 };
 
 void swap(TGetTypeInfoResp &a, TGetTypeInfoResp &b);
@@ -2552,16 +2557,15 @@ class TGetCatalogsReq {
   static const char* ascii_fingerprint; // = "82377107F8BD0526960537D5A112E6EF";
   static const uint8_t binary_fingerprint[16]; // = {0x82,0x37,0x71,0x07,0xF8,0xBD,0x05,0x26,0x96,0x05,0x37,0xD5,0xA1,0x12,0xE6,0xEF};
 
+  TGetCatalogsReq(const TGetCatalogsReq&);
+  TGetCatalogsReq& operator=(const TGetCatalogsReq&);
   TGetCatalogsReq() {
   }
 
-  virtual ~TGetCatalogsReq() throw() {}
-
+  virtual ~TGetCatalogsReq() throw();
   TSessionHandle sessionHandle;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
   bool operator == (const TGetCatalogsReq & rhs) const
   {
@@ -2578,13 +2582,14 @@ class TGetCatalogsReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetCatalogsReq& obj);
 };
 
 void swap(TGetCatalogsReq &a, TGetCatalogsReq &b);
 
 typedef struct _TGetCatalogsResp__isset {
   _TGetCatalogsResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetCatalogsResp__isset;
 
 class TGetCatalogsResp {
@@ -2593,24 +2598,20 @@ class TGetCatalogsResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetCatalogsResp(const TGetCatalogsResp&);
+  TGetCatalogsResp& operator=(const TGetCatalogsResp&);
   TGetCatalogsResp() {
   }
 
-  virtual ~TGetCatalogsResp() throw() {}
-
+  virtual ~TGetCatalogsResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetCatalogsResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetCatalogsResp & rhs) const
   {
@@ -2631,14 +2632,15 @@ class TGetCatalogsResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetCatalogsResp& obj);
 };
 
 void swap(TGetCatalogsResp &a, TGetCatalogsResp &b);
 
 typedef struct _TGetSchemasReq__isset {
   _TGetSchemasReq__isset() : catalogName(false), schemaName(false) {}
-  bool catalogName;
-  bool schemaName;
+  bool catalogName :1;
+  bool schemaName :1;
 } _TGetSchemasReq__isset;
 
 class TGetSchemasReq {
@@ -2647,30 +2649,23 @@ class TGetSchemasReq {
   static const char* ascii_fingerprint; // = "28A9D12DE8393DD3E73FC1E5AE6E113B";
   static const uint8_t binary_fingerprint[16]; // = {0x28,0xA9,0xD1,0x2D,0xE8,0x39,0x3D,0xD3,0xE7,0x3F,0xC1,0xE5,0xAE,0x6E,0x11,0x3B};
 
+  TGetSchemasReq(const TGetSchemasReq&);
+  TGetSchemasReq& operator=(const TGetSchemasReq&);
   TGetSchemasReq() : catalogName(), schemaName() {
   }
 
-  virtual ~TGetSchemasReq() throw() {}
-
+  virtual ~TGetSchemasReq() throw();
   TSessionHandle sessionHandle;
   TIdentifier catalogName;
   TPatternOrIdentifier schemaName;
 
   _TGetSchemasReq__isset __isset;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_catalogName(const TIdentifier& val) {
-    catalogName = val;
-    __isset.catalogName = true;
-  }
+  void __set_catalogName(const TIdentifier& val);
 
-  void __set_schemaName(const TPatternOrIdentifier& val) {
-    schemaName = val;
-    __isset.schemaName = true;
-  }
+  void __set_schemaName(const TPatternOrIdentifier& val);
 
   bool operator == (const TGetSchemasReq & rhs) const
   {
@@ -2695,13 +2690,14 @@ class TGetSchemasReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetSchemasReq& obj);
 };
 
 void swap(TGetSchemasReq &a, TGetSchemasReq &b);
 
 typedef struct _TGetSchemasResp__isset {
   _TGetSchemasResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetSchemasResp__isset;
 
 class TGetSchemasResp {
@@ -2710,24 +2706,20 @@ class TGetSchemasResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetSchemasResp(const TGetSchemasResp&);
+  TGetSchemasResp& operator=(const TGetSchemasResp&);
   TGetSchemasResp() {
   }
 
-  virtual ~TGetSchemasResp() throw() {}
-
+  virtual ~TGetSchemasResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetSchemasResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetSchemasResp & rhs) const
   {
@@ -2748,16 +2740,17 @@ class TGetSchemasResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetSchemasResp& obj);
 };
 
 void swap(TGetSchemasResp &a, TGetSchemasResp &b);
 
 typedef struct _TGetTablesReq__isset {
   _TGetTablesReq__isset() : catalogName(false), schemaName(false), tableName(false), tableTypes(false) {}
-  bool catalogName;
-  bool schemaName;
-  bool tableName;
-  bool tableTypes;
+  bool catalogName :1;
+  bool schemaName :1;
+  bool tableName :1;
+  bool tableTypes :1;
 } _TGetTablesReq__isset;
 
 class TGetTablesReq {
@@ -2766,11 +2759,12 @@ class TGetTablesReq {
   static const char* ascii_fingerprint; // = "C80DFEE06850052F5A445BE81ED763DB";
   static const uint8_t binary_fingerprint[16]; // = {0xC8,0x0D,0xFE,0xE0,0x68,0x50,0x05,0x2F,0x5A,0x44,0x5B,0xE8,0x1E,0xD7,0x63,0xDB};
 
+  TGetTablesReq(const TGetTablesReq&);
+  TGetTablesReq& operator=(const TGetTablesReq&);
   TGetTablesReq() : catalogName(), schemaName(), tableName() {
   }
 
-  virtual ~TGetTablesReq() throw() {}
-
+  virtual ~TGetTablesReq() throw();
   TSessionHandle sessionHandle;
   TPatternOrIdentifier catalogName;
   TPatternOrIdentifier schemaName;
@@ -2779,29 +2773,15 @@ class TGetTablesReq {
 
   _TGetTablesReq__isset __isset;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_catalogName(const TPatternOrIdentifier& val) {
-    catalogName = val;
-    __isset.catalogName = true;
-  }
+  void __set_catalogName(const TPatternOrIdentifier& val);
 
-  void __set_schemaName(const TPatternOrIdentifier& val) {
-    schemaName = val;
-    __isset.schemaName = true;
-  }
+  void __set_schemaName(const TPatternOrIdentifier& val);
 
-  void __set_tableName(const TPatternOrIdentifier& val) {
-    tableName = val;
-    __isset.tableName = true;
-  }
+  void __set_tableName(const TPatternOrIdentifier& val);
 
-  void __set_tableTypes(const std::vector<std::string> & val) {
-    tableTypes = val;
-    __isset.tableTypes = true;
-  }
+  void __set_tableTypes(const std::vector<std::string> & val);
 
   bool operator == (const TGetTablesReq & rhs) const
   {
@@ -2834,13 +2814,14 @@ class TGetTablesReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTablesReq& obj);
 };
 
 void swap(TGetTablesReq &a, TGetTablesReq &b);
 
 typedef struct _TGetTablesResp__isset {
   _TGetTablesResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetTablesResp__isset;
 
 class TGetTablesResp {
@@ -2849,24 +2830,20 @@ class TGetTablesResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetTablesResp(const TGetTablesResp&);
+  TGetTablesResp& operator=(const TGetTablesResp&);
   TGetTablesResp() {
   }
 
-  virtual ~TGetTablesResp() throw() {}
-
+  virtual ~TGetTablesResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetTablesResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetTablesResp & rhs) const
   {
@@ -2887,6 +2864,7 @@ class TGetTablesResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTablesResp& obj);
 };
 
 void swap(TGetTablesResp &a, TGetTablesResp &b);
@@ -2898,16 +2876,15 @@ class TGetTableTypesReq {
   static const char* ascii_fingerprint; // = "82377107F8BD0526960537D5A112E6EF";
   static const uint8_t binary_fingerprint[16]; // = {0x82,0x37,0x71,0x07,0xF8,0xBD,0x05,0x26,0x96,0x05,0x37,0xD5,0xA1,0x12,0xE6,0xEF};
 
+  TGetTableTypesReq(const TGetTableTypesReq&);
+  TGetTableTypesReq& operator=(const TGetTableTypesReq&);
   TGetTableTypesReq() {
   }
 
-  virtual ~TGetTableTypesReq() throw() {}
-
+  virtual ~TGetTableTypesReq() throw();
   TSessionHandle sessionHandle;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
   bool operator == (const TGetTableTypesReq & rhs) const
   {
@@ -2924,13 +2901,14 @@ class TGetTableTypesReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTableTypesReq& obj);
 };
 
 void swap(TGetTableTypesReq &a, TGetTableTypesReq &b);
 
 typedef struct _TGetTableTypesResp__isset {
   _TGetTableTypesResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetTableTypesResp__isset;
 
 class TGetTableTypesResp {
@@ -2939,24 +2917,20 @@ class TGetTableTypesResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetTableTypesResp(const TGetTableTypesResp&);
+  TGetTableTypesResp& operator=(const TGetTableTypesResp&);
   TGetTableTypesResp() {
   }
 
-  virtual ~TGetTableTypesResp() throw() {}
-
+  virtual ~TGetTableTypesResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetTableTypesResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetTableTypesResp & rhs) const
   {
@@ -2977,16 +2951,17 @@ class TGetTableTypesResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetTableTypesResp& obj);
 };
 
 void swap(TGetTableTypesResp &a, TGetTableTypesResp &b);
 
 typedef struct _TGetColumnsReq__isset {
   _TGetColumnsReq__isset() : catalogName(false), schemaName(false), tableName(false), columnName(false) {}
-  bool catalogName;
-  bool schemaName;
-  bool tableName;
-  bool columnName;
+  bool catalogName :1;
+  bool schemaName :1;
+  bool tableName :1;
+  bool columnName :1;
 } _TGetColumnsReq__isset;
 
 class TGetColumnsReq {
@@ -2995,11 +2970,12 @@ class TGetColumnsReq {
   static const char* ascii_fingerprint; // = "72D0F28ED33A49B7306DF63EEE956C28";
   static const uint8_t binary_fingerprint[16]; // = {0x72,0xD0,0xF2,0x8E,0xD3,0x3A,0x49,0xB7,0x30,0x6D,0xF6,0x3E,0xEE,0x95,0x6C,0x28};
 
+  TGetColumnsReq(const TGetColumnsReq&);
+  TGetColumnsReq& operator=(const TGetColumnsReq&);
   TGetColumnsReq() : catalogName(), schemaName(), tableName(), columnName() {
   }
 
-  virtual ~TGetColumnsReq() throw() {}
-
+  virtual ~TGetColumnsReq() throw();
   TSessionHandle sessionHandle;
   TIdentifier catalogName;
   TPatternOrIdentifier schemaName;
@@ -3008,29 +2984,15 @@ class TGetColumnsReq {
 
   _TGetColumnsReq__isset __isset;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_catalogName(const TIdentifier& val) {
-    catalogName = val;
-    __isset.catalogName = true;
-  }
+  void __set_catalogName(const TIdentifier& val);
 
-  void __set_schemaName(const TPatternOrIdentifier& val) {
-    schemaName = val;
-    __isset.schemaName = true;
-  }
+  void __set_schemaName(const TPatternOrIdentifier& val);
 
-  void __set_tableName(const TPatternOrIdentifier& val) {
-    tableName = val;
-    __isset.tableName = true;
-  }
+  void __set_tableName(const TPatternOrIdentifier& val);
 
-  void __set_columnName(const TPatternOrIdentifier& val) {
-    columnName = val;
-    __isset.columnName = true;
-  }
+  void __set_columnName(const TPatternOrIdentifier& val);
 
   bool operator == (const TGetColumnsReq & rhs) const
   {
@@ -3063,13 +3025,14 @@ class TGetColumnsReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetColumnsReq& obj);
 };
 
 void swap(TGetColumnsReq &a, TGetColumnsReq &b);
 
 typedef struct _TGetColumnsResp__isset {
   _TGetColumnsResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetColumnsResp__isset;
 
 class TGetColumnsResp {
@@ -3078,24 +3041,20 @@ class TGetColumnsResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetColumnsResp(const TGetColumnsResp&);
+  TGetColumnsResp& operator=(const TGetColumnsResp&);
   TGetColumnsResp() {
   }
 
-  virtual ~TGetColumnsResp() throw() {}
-
+  virtual ~TGetColumnsResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetColumnsResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetColumnsResp & rhs) const
   {
@@ -3116,14 +3075,15 @@ class TGetColumnsResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetColumnsResp& obj);
 };
 
 void swap(TGetColumnsResp &a, TGetColumnsResp &b);
 
 typedef struct _TGetFunctionsReq__isset {
   _TGetFunctionsReq__isset() : catalogName(false), schemaName(false) {}
-  bool catalogName;
-  bool schemaName;
+  bool catalogName :1;
+  bool schemaName :1;
 } _TGetFunctionsReq__isset;
 
 class TGetFunctionsReq {
@@ -3132,11 +3092,12 @@ class TGetFunctionsReq {
   static const char* ascii_fingerprint; // = "0887E0916ADE4521BF6017B534493138";
   static const uint8_t binary_fingerprint[16]; // = {0x08,0x87,0xE0,0x91,0x6A,0xDE,0x45,0x21,0xBF,0x60,0x17,0xB5,0x34,0x49,0x31,0x38};
 
+  TGetFunctionsReq(const TGetFunctionsReq&);
+  TGetFunctionsReq& operator=(const TGetFunctionsReq&);
   TGetFunctionsReq() : catalogName(), schemaName(), functionName() {
   }
 
-  virtual ~TGetFunctionsReq() throw() {}
-
+  virtual ~TGetFunctionsReq() throw();
   TSessionHandle sessionHandle;
   TIdentifier catalogName;
   TPatternOrIdentifier schemaName;
@@ -3144,23 +3105,13 @@ class TGetFunctionsReq {
 
   _TGetFunctionsReq__isset __isset;
 
-  void __set_sessionHandle(const TSessionHandle& val) {
-    sessionHandle = val;
-  }
+  void __set_sessionHandle(const TSessionHandle& val);
 
-  void __set_catalogName(const TIdentifier& val) {
-    catalogName = val;
-    __isset.catalogName = true;
-  }
+  void __set_catalogName(const TIdentifier& val);
 
-  void __set_schemaName(const TPatternOrIdentifier& val) {
-    schemaName = val;
-    __isset.schemaName = true;
-  }
+  void __set_schemaName(const TPatternOrIdentifier& val);
 
-  void __set_functionName(const TPatternOrIdentifier& val) {
-    functionName = val;
-  }
+  void __set_functionName(const TPatternOrIdentifier& val);
 
   bool operator == (const TGetFunctionsReq & rhs) const
   {
@@ -3187,13 +3138,14 @@ class TGetFunctionsReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetFunctionsReq& obj);
 };
 
 void swap(TGetFunctionsReq &a, TGetFunctionsReq &b);
 
 typedef struct _TGetFunctionsResp__isset {
   _TGetFunctionsResp__isset() : operationHandle(false) {}
-  bool operationHandle;
+  bool operationHandle :1;
 } _TGetFunctionsResp__isset;
 
 class TGetFunctionsResp {
@@ -3202,24 +3154,20 @@ class TGetFunctionsResp {
   static const char* ascii_fingerprint; // = "02A075A0FF88D3A172916D8F23C7B286";
   static const uint8_t binary_fingerprint[16]; // = {0x02,0xA0,0x75,0xA0,0xFF,0x88,0xD3,0xA1,0x72,0x91,0x6D,0x8F,0x23,0xC7,0xB2,0x86};
 
+  TGetFunctionsResp(const TGetFunctionsResp&);
+  TGetFunctionsResp& operator=(const TGetFunctionsResp&);
   TGetFunctionsResp() {
   }
 
-  virtual ~TGetFunctionsResp() throw() {}
-
+  virtual ~TGetFunctionsResp() throw();
   TStatus status;
   TOperationHandle operationHandle;
 
   _TGetFunctionsResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-    __isset.operationHandle = true;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetFunctionsResp & rhs) const
   {
@@ -3240,6 +3188,7 @@ class TGetFunctionsResp {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetFunctionsResp& obj);
 };
 
 void swap(TGetFunctionsResp &a, TGetFunctionsResp &b);
@@ -3251,16 +3200,15 @@ class TGetOperationStatusReq {
   static const char* ascii_fingerprint; // = "414FA38522AE6B9CEC1438B56CA1DE5A";
   static const uint8_t binary_fingerprint[16]; // = {0x41,0x4F,0xA3,0x85,0x22,0xAE,0x6B,0x9C,0xEC,0x14,0x38,0xB5,0x6C,0xA1,0xDE,0x5A};
 
+  TGetOperationStatusReq(const TGetOperationStatusReq&);
+  TGetOperationStatusReq& operator=(const TGetOperationStatusReq&);
   TGetOperationStatusReq() {
   }
 
-  virtual ~TGetOperationStatusReq() throw() {}
-
+  virtual ~TGetOperationStatusReq() throw();
   TOperationHandle operationHandle;
 
-  void __set_operationHandle(const TOperationHandle& val) {
-    operationHandle = val;
-  }
+  void __set_operationHandle(const TOperationHandle& val);
 
   bool operator == (const TGetOperationStatusReq & rhs) const
   {
@@ -3277,16 +3225,17 @@ class TGetOperationStatusReq {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const TGetOperationStatusReq& obj);
 };
 
 void swap(TGetOperationStatusReq &a, TGetOperationStatusReq &b);
 
 typedef struct _TGetOperationStatusResp__isset {
   _TGetOperationStatusResp__isset() : operationState(false), sqlState(false), errorCode(false), errorMessage(false) {}
-  bool operationState;
-  bool sqlState;
-  bool errorCode;
-  bool errorMessage;
+  bool operationState :1;
+  bool sqlState :1;
+  bool errorCode :1;
+  bool errorMessage :1;
 } _TGetOperationStatusResp__isset;
 
 class TGetOperationStatusResp {
@@ -3295,11 +3244,12 @@ class TGetOperationStatusResp {
   static const char* ascii_fingerprint; // = "BD124DB87A5A2E7D11945BD1B17F013D";
   static const uint8_t binary_fingerprint[16]; // = {0xBD,0x12,0x4D,0xB8,0x7A,0x5A,0x2E,0x7D,0x11,0x94,0x5B,0xD1,0xB1,0x7F,0x01,0x3D};
 
+  TGetOperationStatusResp(const TGetOperationStatusResp&);
+  TGetOperationStatusResp& operator=(const TGetOperationStatusResp&);
   TGetOperationStatusResp() : operationState((TOperationState::type)0), sqlState(), errorCode(0), errorMessage() {
   }
 
-  virtual ~TGetOperationStatusResp() throw() {}
-
+  virtual ~TGetOperationStatusResp() throw();
   TStatus status;
   TOperationState::type operationState;
   std::string sqlState;
@@ -3308,29 +3258,15 @@ class TGetOperationStatusResp {
 
   _TGetOperationStatusResp__isset __isset;
 
-  void __set_status(const TStatus& val) {
-    status = val;
-  }
+  void __set_status(const TStatus& val);
 
-  void __set_operationState(const TOperationState::type val) {
-    operationState = val;
-    __isset.operationState = true;
-  }
+  void __set_operationState(const TOperationState::type val);
 
-  void __set_sqlState(const std::string& val) {
-    sqlState = val;
-    __isset.sqlState = true;
-  }
+  void __set_sqlState(const std::string& val);
 
-  void __set_errorCode(const int32_t val) {
-    errorCode = val;
-    __isset.errorCode = true;
-  }
+  voi

<TRUNCATED>

[48/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)


Project: http://git-wip-us.apache.org/repos/asf/hive/repo
Commit: http://git-wip-us.apache.org/repos/asf/hive/commit/42216997
Tree: http://git-wip-us.apache.org/repos/asf/hive/tree/42216997
Diff: http://git-wip-us.apache.org/repos/asf/hive/diff/42216997

Branch: refs/heads/spark
Commit: 42216997f7fcff1853524b03e3961ec5c21f3fd7
Parents: dddffe1
Author: Chao Sun <su...@apache.org>
Authored: Fri Jul 17 12:51:27 2015 -0700
Committer: Chao Sun <su...@apache.org>
Committed: Fri Jul 17 12:51:27 2015 -0700

----------------------------------------------------------------------
 .../org/apache/hadoop/hive/conf/HiveConf.java   |     7 +
 itests/qtest/pom.xml                            |     2 +-
 .../test/resources/testconfiguration.properties |     6 +
 .../gen/thrift/gen-cpp/ThriftHiveMetastore.cpp  |  4708 ++++-
 .../gen/thrift/gen-cpp/ThriftHiveMetastore.h    |  7807 +++----
 .../thrift/gen-cpp/hive_metastore_constants.cpp |     2 +-
 .../thrift/gen-cpp/hive_metastore_constants.h   |     2 +-
 .../gen/thrift/gen-cpp/hive_metastore_types.cpp |  6044 +++++-
 .../gen/thrift/gen-cpp/hive_metastore_types.h   |  2619 ++-
 .../hive/metastore/api/AbortTxnRequest.java     |    24 +-
 .../metastore/api/AddDynamicPartitions.java     |    69 +-
 .../metastore/api/AddPartitionsRequest.java     |    80 +-
 .../hive/metastore/api/AddPartitionsResult.java |    48 +-
 .../hadoop/hive/metastore/api/AggrStats.java    |    54 +-
 .../metastore/api/AlreadyExistsException.java   |    24 +-
 .../metastore/api/BinaryColumnStatsData.java    |    40 +-
 .../metastore/api/BooleanColumnStatsData.java   |    40 +-
 .../hive/metastore/api/CheckLockRequest.java    |    24 +-
 .../hive/metastore/api/ColumnStatistics.java    |    54 +-
 .../metastore/api/ColumnStatisticsData.java     |    20 +-
 .../metastore/api/ColumnStatisticsDesc.java     |    58 +-
 .../hive/metastore/api/ColumnStatisticsObj.java |    40 +-
 .../hive/metastore/api/CommitTxnRequest.java    |    24 +-
 .../hive/metastore/api/CompactionRequest.java   |    62 +-
 .../hive/metastore/api/CompactionType.java      |     2 +-
 .../api/ConfigValSecurityException.java         |    24 +-
 .../api/CurrentNotificationEventId.java         |    24 +-
 .../hadoop/hive/metastore/api/Database.java     |   115 +-
 .../apache/hadoop/hive/metastore/api/Date.java  |    24 +-
 .../hive/metastore/api/DateColumnStatsData.java |    50 +-
 .../hadoop/hive/metastore/api/Decimal.java      |    41 +-
 .../metastore/api/DecimalColumnStatsData.java   |    50 +-
 .../metastore/api/DoubleColumnStatsData.java    |    50 +-
 .../hive/metastore/api/DropPartitionsExpr.java  |    43 +-
 .../metastore/api/DropPartitionsRequest.java    |    82 +-
 .../metastore/api/DropPartitionsResult.java     |    48 +-
 .../hive/metastore/api/EnvironmentContext.java  |    61 +-
 .../hive/metastore/api/EventRequestType.java    |     2 +-
 .../hadoop/hive/metastore/api/FieldSchema.java  |    58 +-
 .../hive/metastore/api/FireEventRequest.java    |    79 +-
 .../metastore/api/FireEventRequestData.java     |    20 +-
 .../hive/metastore/api/FireEventResponse.java   |    16 +-
 .../hadoop/hive/metastore/api/Function.java     |   110 +-
 .../hadoop/hive/metastore/api/FunctionType.java |     2 +-
 .../metastore/api/GetOpenTxnsInfoResponse.java  |    54 +-
 .../hive/metastore/api/GetOpenTxnsResponse.java |    53 +-
 .../api/GetPrincipalsInRoleRequest.java         |    24 +-
 .../api/GetPrincipalsInRoleResponse.java        |    46 +-
 .../api/GetRoleGrantsForPrincipalRequest.java   |    36 +-
 .../api/GetRoleGrantsForPrincipalResponse.java  |    46 +-
 .../api/GrantRevokePrivilegeRequest.java        |    46 +-
 .../api/GrantRevokePrivilegeResponse.java       |    26 +-
 .../metastore/api/GrantRevokeRoleRequest.java   |    86 +-
 .../metastore/api/GrantRevokeRoleResponse.java  |    26 +-
 .../hive/metastore/api/GrantRevokeType.java     |     2 +-
 .../hive/metastore/api/HeartbeatRequest.java    |    34 +-
 .../metastore/api/HeartbeatTxnRangeRequest.java |    32 +-
 .../api/HeartbeatTxnRangeResponse.java          |    74 +-
 .../hive/metastore/api/HiveObjectPrivilege.java |    52 +-
 .../hive/metastore/api/HiveObjectRef.java       |    81 +-
 .../hive/metastore/api/HiveObjectType.java      |     2 +-
 .../apache/hadoop/hive/metastore/api/Index.java |   133 +-
 .../api/IndexAlreadyExistsException.java        |    24 +-
 .../metastore/api/InsertEventRequestData.java   |    45 +-
 .../metastore/api/InvalidInputException.java    |    24 +-
 .../metastore/api/InvalidObjectException.java   |    24 +-
 .../api/InvalidOperationException.java          |    24 +-
 .../api/InvalidPartitionException.java          |    24 +-
 .../hive/metastore/api/LockComponent.java       |    66 +-
 .../hadoop/hive/metastore/api/LockLevel.java    |     2 +-
 .../hadoop/hive/metastore/api/LockRequest.java  |    72 +-
 .../hadoop/hive/metastore/api/LockResponse.java |    36 +-
 .../hadoop/hive/metastore/api/LockState.java    |     2 +-
 .../hadoop/hive/metastore/api/LockType.java     |     2 +-
 .../hive/metastore/api/LongColumnStatsData.java |    50 +-
 .../hive/metastore/api/MetaException.java       |    24 +-
 .../hive/metastore/api/NoSuchLockException.java |    24 +-
 .../metastore/api/NoSuchObjectException.java    |    24 +-
 .../hive/metastore/api/NoSuchTxnException.java  |    24 +-
 .../hive/metastore/api/NotificationEvent.java   |    66 +-
 .../metastore/api/NotificationEventRequest.java |    34 +-
 .../api/NotificationEventResponse.java          |    46 +-
 .../hive/metastore/api/OpenTxnRequest.java      |    40 +-
 .../hive/metastore/api/OpenTxnsResponse.java    |    45 +-
 .../apache/hadoop/hive/metastore/api/Order.java |    32 +-
 .../hadoop/hive/metastore/api/Partition.java    |   156 +-
 .../hive/metastore/api/PartitionEventType.java  |     2 +-
 .../api/PartitionListComposingSpec.java         |    46 +-
 .../hive/metastore/api/PartitionSpec.java       |    58 +-
 .../api/PartitionSpecWithSharedSD.java          |    54 +-
 .../hive/metastore/api/PartitionWithoutSD.java  |   124 +-
 .../metastore/api/PartitionsByExprRequest.java  |    67 +-
 .../metastore/api/PartitionsByExprResult.java   |    54 +-
 .../metastore/api/PartitionsStatsRequest.java   |    90 +-
 .../metastore/api/PartitionsStatsResult.java    |    72 +-
 .../metastore/api/PrincipalPrivilegeSet.java    |   184 +-
 .../hive/metastore/api/PrincipalType.java       |     2 +-
 .../hadoop/hive/metastore/api/PrivilegeBag.java |    46 +-
 .../hive/metastore/api/PrivilegeGrantInfo.java  |    60 +-
 .../hive/metastore/api/RequestPartsSpec.java    |    56 +-
 .../hadoop/hive/metastore/api/ResourceType.java |     2 +-
 .../hadoop/hive/metastore/api/ResourceUri.java  |    36 +-
 .../apache/hadoop/hive/metastore/api/Role.java  |    40 +-
 .../hive/metastore/api/RolePrincipalGrant.java  |    80 +-
 .../hadoop/hive/metastore/api/Schema.java       |    91 +-
 .../hadoop/hive/metastore/api/SerDeInfo.java    |    93 +-
 .../api/SetPartitionsStatsRequest.java          |    46 +-
 .../hive/metastore/api/ShowCompactRequest.java  |    16 +-
 .../hive/metastore/api/ShowCompactResponse.java |    46 +-
 .../api/ShowCompactResponseElement.java         |    86 +-
 .../hive/metastore/api/ShowLocksRequest.java    |    16 +-
 .../hive/metastore/api/ShowLocksResponse.java   |    46 +-
 .../metastore/api/ShowLocksResponseElement.java |   114 +-
 .../hadoop/hive/metastore/api/SkewedInfo.java   |   147 +-
 .../hive/metastore/api/StorageDescriptor.java   |   242 +-
 .../metastore/api/StringColumnStatsData.java    |    48 +-
 .../apache/hadoop/hive/metastore/api/Table.java |   189 +-
 .../hive/metastore/api/TableStatsRequest.java   |    61 +-
 .../hive/metastore/api/TableStatsResult.java    |    46 +-
 .../hive/metastore/api/ThriftHiveMetastore.java | 18497 ++++++++++++-----
 .../hive/metastore/api/TxnAbortedException.java |    24 +-
 .../hadoop/hive/metastore/api/TxnInfo.java      |    52 +-
 .../hive/metastore/api/TxnOpenException.java    |    24 +-
 .../hadoop/hive/metastore/api/TxnState.java     |     2 +-
 .../apache/hadoop/hive/metastore/api/Type.java  |    72 +-
 .../hive/metastore/api/UnknownDBException.java  |    24 +-
 .../api/UnknownPartitionException.java          |    24 +-
 .../metastore/api/UnknownTableException.java    |    24 +-
 .../hive/metastore/api/UnlockRequest.java       |    24 +-
 .../hadoop/hive/metastore/api/Version.java      |    32 +-
 .../metastore/api/hive_metastoreConstants.java  |     7 +-
 .../gen-php/metastore/ThriftHiveMetastore.php   |  3328 ++-
 .../src/gen/thrift/gen-php/metastore/Types.php  |  1081 +-
 .../hive_metastore/ThriftHiveMetastore-remote   |   609 +-
 .../hive_metastore/ThriftHiveMetastore.py       |  3726 +++-
 .../thrift/gen-py/hive_metastore/constants.py   |     2 +-
 .../gen/thrift/gen-py/hive_metastore/ttypes.py  |   782 +-
 .../thrift/gen-rb/hive_metastore_constants.rb   |     2 +-
 .../gen/thrift/gen-rb/hive_metastore_types.rb   |     2 +-
 .../gen/thrift/gen-rb/thrift_hive_metastore.rb  |     2 +-
 ql/if/queryplan.thrift                          |     1 +
 .../gen/thrift/gen-cpp/queryplan_constants.cpp  |     2 +-
 ql/src/gen/thrift/gen-cpp/queryplan_constants.h |     2 +-
 ql/src/gen/thrift/gen-cpp/queryplan_types.cpp   |   796 +-
 ql/src/gen/thrift/gen-cpp/queryplan_types.h     |   294 +-
 .../hadoop/hive/ql/plan/api/Adjacency.java      |    65 +-
 .../hadoop/hive/ql/plan/api/AdjacencyType.java  |     2 +-
 .../apache/hadoop/hive/ql/plan/api/Graph.java   |    87 +-
 .../hadoop/hive/ql/plan/api/NodeType.java       |     2 +-
 .../hadoop/hive/ql/plan/api/Operator.java       |   142 +-
 .../hadoop/hive/ql/plan/api/OperatorType.java   |     7 +-
 .../apache/hadoop/hive/ql/plan/api/Query.java   |   176 +-
 .../hadoop/hive/ql/plan/api/QueryPlan.java      |    62 +-
 .../apache/hadoop/hive/ql/plan/api/Stage.java   |   172 +-
 .../hadoop/hive/ql/plan/api/StageType.java      |     2 +-
 .../apache/hadoop/hive/ql/plan/api/Task.java    |   182 +-
 .../hadoop/hive/ql/plan/api/TaskType.java       |     2 +-
 ql/src/gen/thrift/gen-php/Types.php             |   119 +-
 ql/src/gen/thrift/gen-py/queryplan/constants.py |     2 +-
 ql/src/gen/thrift/gen-py/queryplan/ttypes.py    |    87 +-
 ql/src/gen/thrift/gen-rb/queryplan_constants.rb |     2 +-
 ql/src/gen/thrift/gen-rb/queryplan_types.rb     |     7 +-
 .../hadoop/hive/ql/exec/OperatorFactory.java    |     8 +
 .../ql/exec/spark/HiveSparkClientFactory.java   |     5 +-
 .../exec/spark/SparkDynamicPartitionPruner.java |   268 +
 .../hive/ql/exec/spark/SparkUtilities.java      |    56 +
 ...VectorSparkPartitionPruningSinkOperator.java |    99 +
 .../hive/ql/io/CombineHiveInputFormat.java      |    59 +-
 .../hadoop/hive/ql/io/HiveInputFormat.java      |    46 +-
 .../DynamicPartitionPruningOptimization.java    |    44 +-
 .../hadoop/hive/ql/optimizer/Optimizer.java     |     2 +-
 .../SparkRemoveDynamicPruningBySize.java        |    73 +
 .../hive/ql/optimizer/physical/Vectorizer.java  |     2 +
 .../spark/SparkPartitionPruningSinkDesc.java    |   100 +
 .../ql/parse/spark/GenSparkProcContext.java     |    14 +-
 .../hive/ql/parse/spark/GenSparkUtils.java      |   111 +-
 .../parse/spark/OptimizeSparkProcContext.java   |    16 +-
 .../hive/ql/parse/spark/SparkCompiler.java      |   177 +-
 .../SparkPartitionPruningSinkOperator.java      |   142 +
 .../hive/ql/parse/spark/SplitOpTreeForDPP.java  |   151 +
 .../org/apache/hadoop/hive/ql/plan/MapWork.java |    10 +
 .../hadoop/hive/ql/plan/TableScanDesc.java      |     6 +-
 .../hive/ql/ppd/SyntheticJoinPredicate.java     |    14 +-
 .../spark_dynamic_partition_pruning.q           |   180 +
 .../spark_dynamic_partition_pruning_2.q         |   118 +
 ...spark_vectorized_dynamic_partition_pruning.q |   192 +
 .../results/clientpositive/spark/bucket2.q.out  |     3 -
 .../results/clientpositive/spark/bucket3.q.out  |     3 -
 .../results/clientpositive/spark/bucket4.q.out  |     3 -
 .../spark/column_access_stats.q.out             |     4 -
 .../spark/limit_partition_metadataonly.q.out    |     2 -
 .../spark/list_bucket_dml_2.q.java1.7.out       |     3 -
 .../spark/optimize_nullscan.q.out               |     3 -
 .../test/results/clientpositive/spark/pcr.q.out |     6 -
 .../results/clientpositive/spark/sample3.q.out  |     3 -
 .../results/clientpositive/spark/sample9.q.out  |     3 -
 .../clientpositive/spark/smb_mapjoin_11.q.out   |     6 -
 .../spark/spark_dynamic_partition_pruning.q.out |  5573 +++++
 .../spark_dynamic_partition_pruning_2.q.out     |  1015 +
 ...k_vectorized_dynamic_partition_pruning.q.out |  5822 ++++++
 .../clientpositive/spark/udf_example_add.q.out  |     3 -
 .../clientpositive/spark/udf_in_file.q.out      |     3 -
 .../clientpositive/spark/union_view.q.out       |     9 -
 .../clientpositive/spark/vector_elt.q.out       |     7 -
 .../spark/vector_string_concat.q.out            |     3 -
 .../spark/vectorization_decimal_date.q.out      |     4 -
 .../spark/vectorization_div0.q.out              |     3 -
 .../clientpositive/spark/vectorized_case.q.out  |     3 -
 .../spark/vectorized_math_funcs.q.out           |     3 -
 .../spark/vectorized_string_funcs.q.out         |     3 -
 .../gen/thrift/gen-cpp/complex_constants.cpp    |     2 +-
 .../src/gen/thrift/gen-cpp/complex_constants.h  |     2 +-
 serde/src/gen/thrift/gen-cpp/complex_types.cpp  |   442 +-
 serde/src/gen/thrift/gen-cpp/complex_types.h    |   174 +-
 .../gen/thrift/gen-cpp/megastruct_constants.cpp |     2 +-
 .../gen/thrift/gen-cpp/megastruct_constants.h   |     2 +-
 .../src/gen/thrift/gen-cpp/megastruct_types.cpp |   585 +-
 serde/src/gen/thrift/gen-cpp/megastruct_types.h |   175 +-
 .../src/gen/thrift/gen-cpp/serde_constants.cpp  |     2 +-
 serde/src/gen/thrift/gen-cpp/serde_constants.h  |     2 +-
 serde/src/gen/thrift/gen-cpp/serde_types.cpp    |     5 +-
 serde/src/gen/thrift/gen-cpp/serde_types.h      |     5 +-
 .../gen/thrift/gen-cpp/testthrift_constants.cpp |     2 +-
 .../gen/thrift/gen-cpp/testthrift_constants.h   |     2 +-
 .../src/gen/thrift/gen-cpp/testthrift_types.cpp |    95 +-
 serde/src/gen/thrift/gen-cpp/testthrift_types.h |    45 +-
 .../hadoop/hive/serde/serdeConstants.java       |     7 +-
 .../hadoop/hive/serde/test/InnerStruct.java     |    24 +-
 .../hadoop/hive/serde/test/ThriftTestObj.java   |    62 +-
 .../hadoop/hive/serde2/thrift/test/Complex.java |   279 +-
 .../hive/serde2/thrift/test/IntString.java      |    40 +-
 .../hive/serde2/thrift/test/MegaStruct.java     |   521 +-
 .../hive/serde2/thrift/test/MiniStruct.java     |    38 +-
 .../hadoop/hive/serde2/thrift/test/MyEnum.java  |     2 +-
 .../hive/serde2/thrift/test/PropValueUnion.java |    60 +-
 .../hive/serde2/thrift/test/SetIntString.java   |    54 +-
 serde/src/gen/thrift/gen-php/Types.php          |    15 +-
 .../org/apache/hadoop/hive/serde/Types.php      |   373 +-
 .../src/gen/thrift/gen-py/complex/constants.py  |     2 +-
 serde/src/gen/thrift/gen-py/complex/ttypes.py   |    50 +-
 .../gen/thrift/gen-py/megastruct/constants.py   |     2 +-
 .../src/gen/thrift/gen-py/megastruct/ttypes.py  |    44 +-
 .../org_apache_hadoop_hive_serde/constants.py   |     2 +-
 .../org_apache_hadoop_hive_serde/ttypes.py      |     2 +-
 .../gen/thrift/gen-py/testthrift/constants.py   |     2 +-
 .../src/gen/thrift/gen-py/testthrift/ttypes.py  |    14 +-
 .../src/gen/thrift/gen-rb/complex_constants.rb  |     2 +-
 serde/src/gen/thrift/gen-rb/complex_types.rb    |     2 +-
 .../gen/thrift/gen-rb/megastruct_constants.rb   |     2 +-
 serde/src/gen/thrift/gen-rb/megastruct_types.rb |     2 +-
 serde/src/gen/thrift/gen-rb/serde_constants.rb  |     2 +-
 serde/src/gen/thrift/gen-rb/serde_types.rb      |     2 +-
 .../gen/thrift/gen-rb/testthrift_constants.rb   |     2 +-
 serde/src/gen/thrift/gen-rb/testthrift_types.rb |     2 +-
 service/src/gen/thrift/gen-cpp/TCLIService.cpp  |   458 +-
 service/src/gen/thrift/gen-cpp/TCLIService.h    |   821 +-
 .../thrift/gen-cpp/TCLIService_constants.cpp    |     2 +-
 .../gen/thrift/gen-cpp/TCLIService_constants.h  |     2 +-
 .../gen/thrift/gen-cpp/TCLIService_types.cpp    |  3250 ++-
 .../src/gen/thrift/gen-cpp/TCLIService_types.h  |  1482 +-
 service/src/gen/thrift/gen-cpp/ThriftHive.cpp   |   286 +-
 service/src/gen/thrift/gen-cpp/ThriftHive.h     |   389 +-
 .../thrift/gen-cpp/hive_service_constants.cpp   |     2 +-
 .../gen/thrift/gen-cpp/hive_service_constants.h |     2 +-
 .../gen/thrift/gen-cpp/hive_service_types.cpp   |   110 +-
 .../src/gen/thrift/gen-cpp/hive_service_types.h |    75 +-
 .../hadoop/hive/service/HiveClusterStatus.java  |    68 +-
 .../hive/service/HiveServerException.java       |    40 +-
 .../hadoop/hive/service/JobTrackerState.java    |     2 +-
 .../apache/hadoop/hive/service/ThriftHive.java  |   914 +-
 .../service/cli/thrift/TArrayTypeEntry.java     |    24 +-
 .../hive/service/cli/thrift/TBinaryColumn.java  |    64 +-
 .../hive/service/cli/thrift/TBoolColumn.java    |    62 +-
 .../hive/service/cli/thrift/TBoolValue.java     |    26 +-
 .../hive/service/cli/thrift/TByteColumn.java    |    62 +-
 .../hive/service/cli/thrift/TByteValue.java     |    26 +-
 .../hive/service/cli/thrift/TCLIService.java    |  1734 +-
 .../cli/thrift/TCLIServiceConstants.java        |     7 +-
 .../cli/thrift/TCancelDelegationTokenReq.java   |    32 +-
 .../cli/thrift/TCancelDelegationTokenResp.java  |    24 +-
 .../service/cli/thrift/TCancelOperationReq.java |    24 +-
 .../cli/thrift/TCancelOperationResp.java        |    24 +-
 .../service/cli/thrift/TCloseOperationReq.java  |    24 +-
 .../service/cli/thrift/TCloseOperationResp.java |    24 +-
 .../service/cli/thrift/TCloseSessionReq.java    |    24 +-
 .../service/cli/thrift/TCloseSessionResp.java   |    24 +-
 .../apache/hive/service/cli/thrift/TColumn.java |    20 +-
 .../hive/service/cli/thrift/TColumnDesc.java    |    50 +-
 .../hive/service/cli/thrift/TColumnValue.java   |    20 +-
 .../hive/service/cli/thrift/TDoubleColumn.java  |    62 +-
 .../hive/service/cli/thrift/TDoubleValue.java   |    26 +-
 .../cli/thrift/TExecuteStatementReq.java        |    87 +-
 .../cli/thrift/TExecuteStatementResp.java       |    34 +-
 .../service/cli/thrift/TFetchOrientation.java   |     2 +-
 .../service/cli/thrift/TFetchResultsReq.java    |    54 +-
 .../service/cli/thrift/TFetchResultsResp.java   |    42 +-
 .../service/cli/thrift/TGetCatalogsReq.java     |    24 +-
 .../service/cli/thrift/TGetCatalogsResp.java    |    34 +-
 .../hive/service/cli/thrift/TGetColumnsReq.java |    58 +-
 .../service/cli/thrift/TGetColumnsResp.java     |    34 +-
 .../cli/thrift/TGetDelegationTokenReq.java      |    40 +-
 .../cli/thrift/TGetDelegationTokenResp.java     |    34 +-
 .../service/cli/thrift/TGetFunctionsReq.java    |    50 +-
 .../service/cli/thrift/TGetFunctionsResp.java   |    34 +-
 .../hive/service/cli/thrift/TGetInfoReq.java    |    36 +-
 .../hive/service/cli/thrift/TGetInfoResp.java   |    32 +-
 .../hive/service/cli/thrift/TGetInfoType.java   |     2 +-
 .../hive/service/cli/thrift/TGetInfoValue.java  |    20 +-
 .../cli/thrift/TGetOperationStatusReq.java      |    24 +-
 .../cli/thrift/TGetOperationStatusResp.java     |    62 +-
 .../cli/thrift/TGetResultSetMetadataReq.java    |    24 +-
 .../cli/thrift/TGetResultSetMetadataResp.java   |    34 +-
 .../hive/service/cli/thrift/TGetSchemasReq.java |    42 +-
 .../service/cli/thrift/TGetSchemasResp.java     |    34 +-
 .../service/cli/thrift/TGetTableTypesReq.java   |    24 +-
 .../service/cli/thrift/TGetTableTypesResp.java  |    34 +-
 .../hive/service/cli/thrift/TGetTablesReq.java  |    79 +-
 .../hive/service/cli/thrift/TGetTablesResp.java |    34 +-
 .../service/cli/thrift/TGetTypeInfoReq.java     |    24 +-
 .../service/cli/thrift/TGetTypeInfoResp.java    |    34 +-
 .../service/cli/thrift/THandleIdentifier.java   |    50 +-
 .../hive/service/cli/thrift/TI16Column.java     |    62 +-
 .../hive/service/cli/thrift/TI16Value.java      |    26 +-
 .../hive/service/cli/thrift/TI32Column.java     |    62 +-
 .../hive/service/cli/thrift/TI32Value.java      |    26 +-
 .../hive/service/cli/thrift/TI64Column.java     |    62 +-
 .../hive/service/cli/thrift/TI64Value.java      |    26 +-
 .../hive/service/cli/thrift/TMapTypeEntry.java  |    32 +-
 .../service/cli/thrift/TOpenSessionReq.java     |    91 +-
 .../service/cli/thrift/TOpenSessionResp.java    |    91 +-
 .../service/cli/thrift/TOperationHandle.java    |    54 +-
 .../service/cli/thrift/TOperationState.java     |     2 +-
 .../hive/service/cli/thrift/TOperationType.java |     2 +-
 .../service/cli/thrift/TPrimitiveTypeEntry.java |    38 +-
 .../service/cli/thrift/TProtocolVersion.java    |     2 +-
 .../cli/thrift/TRenewDelegationTokenReq.java    |    32 +-
 .../cli/thrift/TRenewDelegationTokenResp.java   |    24 +-
 .../apache/hive/service/cli/thrift/TRow.java    |    46 +-
 .../apache/hive/service/cli/thrift/TRowSet.java |    86 +-
 .../hive/service/cli/thrift/TSessionHandle.java |    24 +-
 .../apache/hive/service/cli/thrift/TStatus.java |    83 +-
 .../hive/service/cli/thrift/TStatusCode.java    |     2 +-
 .../hive/service/cli/thrift/TStringColumn.java  |    62 +-
 .../hive/service/cli/thrift/TStringValue.java   |    26 +-
 .../service/cli/thrift/TStructTypeEntry.java    |    50 +-
 .../hive/service/cli/thrift/TTableSchema.java   |    46 +-
 .../hive/service/cli/thrift/TTypeDesc.java      |    46 +-
 .../hive/service/cli/thrift/TTypeEntry.java     |    20 +-
 .../apache/hive/service/cli/thrift/TTypeId.java |     2 +-
 .../service/cli/thrift/TTypeQualifierValue.java |    20 +-
 .../service/cli/thrift/TTypeQualifiers.java     |    54 +-
 .../service/cli/thrift/TUnionTypeEntry.java     |    50 +-
 .../cli/thrift/TUserDefinedTypeEntry.java       |    24 +-
 service/src/gen/thrift/gen-php/TCLIService.php  |   269 +-
 service/src/gen/thrift/gen-php/ThriftHive.php   |   125 +-
 service/src/gen/thrift/gen-php/Types.php        |    30 +-
 .../gen-py/TCLIService/TCLIService-remote       |   102 +-
 .../thrift/gen-py/TCLIService/TCLIService.py    |   439 +-
 .../gen/thrift/gen-py/TCLIService/constants.py  |     2 +-
 .../src/gen/thrift/gen-py/TCLIService/ttypes.py |   478 +-
 .../gen-py/hive_service/ThriftHive-remote       |  1014 +-
 .../thrift/gen-py/hive_service/ThriftHive.py    |   266 +-
 .../gen/thrift/gen-py/hive_service/constants.py |     2 +-
 .../gen/thrift/gen-py/hive_service/ttypes.py    |    19 +-
 .../gen/thrift/gen-rb/hive_service_constants.rb |     2 +-
 .../src/gen/thrift/gen-rb/hive_service_types.rb |     2 +-
 .../src/gen/thrift/gen-rb/t_c_l_i_service.rb    |     2 +-
 .../thrift/gen-rb/t_c_l_i_service_constants.rb  |     2 +-
 .../gen/thrift/gen-rb/t_c_l_i_service_types.rb  |     2 +-
 service/src/gen/thrift/gen-rb/thrift_hive.rb    |     2 +-
 370 files changed, 67652 insertions(+), 22750 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/common/src/java/org/apache/hadoop/hive/conf/HiveConf.java
----------------------------------------------------------------------
diff --git a/common/src/java/org/apache/hadoop/hive/conf/HiveConf.java b/common/src/java/org/apache/hadoop/hive/conf/HiveConf.java
index 27f68df..736a22d 100644
--- a/common/src/java/org/apache/hadoop/hive/conf/HiveConf.java
+++ b/common/src/java/org/apache/hadoop/hive/conf/HiveConf.java
@@ -2187,6 +2187,13 @@ public class HiveConf extends Configuration {
       "Channel logging level for remote Spark driver.  One of {DEBUG, ERROR, INFO, TRACE, WARN}."),
     SPARK_RPC_SASL_MECHANISM("hive.spark.client.rpc.sasl.mechanisms", "DIGEST-MD5",
       "Name of the SASL mechanism to use for authentication."),
+    SPARK_DYNAMIC_PARTITION_PRUNING(
+        "hive.spark.dynamic.partition.pruning", false,
+        "When dynamic pruning is enabled, joins on partition keys will be processed by writing\n" +
+            "to a temporary HDFS file, and read later for removing unnecessary partitions."),
+    SPARK_DYNAMIC_PARTITION_PRUNING_MAX_DATA_SIZE(
+        "hive.spark.dynamic.partition.pruning.max.data.size", 100*1024*1024L,
+        "Maximum total data size in dynamic pruning."),
     NWAYJOINREORDER("hive.reorder.nway.joins", true,
       "Runs reordering of tables within single n-way join (i.e.: picks streamtable)"),
     HIVE_LOG_N_RECORDS("hive.log.every.n.records", 0L, new RangeValidator(0L, null),

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/itests/qtest/pom.xml
----------------------------------------------------------------------
diff --git a/itests/qtest/pom.xml b/itests/qtest/pom.xml
index e195bee..44d30da 100644
--- a/itests/qtest/pom.xml
+++ b/itests/qtest/pom.xml
@@ -429,7 +429,7 @@
                   templatePath="${basedir}/${hive.path.to.root}/ql/src/test/templates/" template="TestCliDriver.vm"
                   queryDirectory="${basedir}/${hive.path.to.root}/ql/src/test/queries/clientpositive/"
                   queryFile="${qfile}"
-                  excludeQueryFile="${minimr.query.files},${minitez.query.files},${encrypted.query.files}"
+                  excludeQueryFile="${minimr.query.files},${minitez.query.files},${encrypted.query.files},${spark.only.query.files}"
                   queryFileRegex="${qfile_regex}"
                   clusterMode="${clustermode}"
                   runDisabled="${run_disabled}"

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/itests/src/test/resources/testconfiguration.properties
----------------------------------------------------------------------
diff --git a/itests/src/test/resources/testconfiguration.properties b/itests/src/test/resources/testconfiguration.properties
index f4ae684..2cf4920 100644
--- a/itests/src/test/resources/testconfiguration.properties
+++ b/itests/src/test/resources/testconfiguration.properties
@@ -1122,6 +1122,12 @@ spark.query.files=add_part_multiple.q, \
   vectorized_timestamp_funcs.q, \
   windowing.q
 
+# Unlike "spark.query.files" above, these tests only run
+# under Spark engine.
+spark.only.query.files=spark_dynamic_partition_pruning.q,\
+  spark_dynamic_partition_pruning_2.q,\
+  spark_vectorized_dynamic_partition_pruning.q
+
 miniSparkOnYarn.query.files=auto_sortmerge_join_16.q,\
   bucket4.q,\
   bucket5.q,\


[38/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InsertEventRequestData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InsertEventRequestData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InsertEventRequestData.java
index c1992c0..673d4d1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InsertEventRequestData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InsertEventRequestData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEventRequestData, InsertEventRequestData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEventRequestData, InsertEventRequestData._Fields>, java.io.Serializable, Cloneable, Comparable<InsertEventRequestData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InsertEventRequestData");
 
   private static final org.apache.thrift.protocol.TField FILES_ADDED_FIELD_DESC = new org.apache.thrift.protocol.TField("filesAdded", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,10 +132,7 @@ public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEve
    */
   public InsertEventRequestData(InsertEventRequestData other) {
     if (other.isSetFilesAdded()) {
-      List<String> __this__filesAdded = new ArrayList<String>();
-      for (String other_element : other.filesAdded) {
-        __this__filesAdded.add(other_element);
-      }
+      List<String> __this__filesAdded = new ArrayList<String>(other.filesAdded);
       this.filesAdded = __this__filesAdded;
     }
   }
@@ -245,30 +246,30 @@ public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEve
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_filesAdded = true && (isSetFilesAdded());
-    builder.append(present_filesAdded);
+    list.add(present_filesAdded);
     if (present_filesAdded)
-      builder.append(filesAdded);
+      list.add(filesAdded);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InsertEventRequestData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InsertEventRequestData typedOther = (InsertEventRequestData)other;
 
-    lastComparison = Boolean.valueOf(isSetFilesAdded()).compareTo(typedOther.isSetFilesAdded());
+    lastComparison = Boolean.valueOf(isSetFilesAdded()).compareTo(other.isSetFilesAdded());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFilesAdded()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.filesAdded, typedOther.filesAdded);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.filesAdded, other.filesAdded);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,11 +353,11 @@ public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEve
               {
                 org.apache.thrift.protocol.TList _list508 = iprot.readListBegin();
                 struct.filesAdded = new ArrayList<String>(_list508.size);
-                for (int _i509 = 0; _i509 < _list508.size; ++_i509)
+                String _elem509;
+                for (int _i510 = 0; _i510 < _list508.size; ++_i510)
                 {
-                  String _elem510; // optional
-                  _elem510 = iprot.readString();
-                  struct.filesAdded.add(_elem510);
+                  _elem509 = iprot.readString();
+                  struct.filesAdded.add(_elem509);
                 }
                 iprot.readListEnd();
               }
@@ -422,11 +423,11 @@ public class InsertEventRequestData implements org.apache.thrift.TBase<InsertEve
       {
         org.apache.thrift.protocol.TList _list513 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.filesAdded = new ArrayList<String>(_list513.size);
-        for (int _i514 = 0; _i514 < _list513.size; ++_i514)
+        String _elem514;
+        for (int _i515 = 0; _i515 < _list513.size; ++_i515)
         {
-          String _elem515; // optional
-          _elem515 = iprot.readString();
-          struct.filesAdded.add(_elem515);
+          _elem514 = iprot.readString();
+          struct.filesAdded.add(_elem514);
         }
       }
       struct.setFilesAddedIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidInputException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidInputException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidInputException.java
index 4b63e3f..6f15ad0 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidInputException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidInputException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InvalidInputException extends TException implements org.apache.thrift.TBase<InvalidInputException, InvalidInputException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InvalidInputException extends TException implements org.apache.thrift.TBase<InvalidInputException, InvalidInputException._Fields>, java.io.Serializable, Cloneable, Comparable<InvalidInputException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InvalidInputException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class InvalidInputException extends TException implements org.apache.thri
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InvalidInputException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InvalidInputException typedOther = (InvalidInputException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidObjectException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidObjectException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidObjectException.java
index 2f1414e..7c0960d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidObjectException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidObjectException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InvalidObjectException extends TException implements org.apache.thrift.TBase<InvalidObjectException, InvalidObjectException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InvalidObjectException extends TException implements org.apache.thrift.TBase<InvalidObjectException, InvalidObjectException._Fields>, java.io.Serializable, Cloneable, Comparable<InvalidObjectException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InvalidObjectException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class InvalidObjectException extends TException implements org.apache.thr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InvalidObjectException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InvalidObjectException typedOther = (InvalidObjectException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidOperationException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidOperationException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidOperationException.java
index 9b6acb8..2cfaec4 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidOperationException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidOperationException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InvalidOperationException extends TException implements org.apache.thrift.TBase<InvalidOperationException, InvalidOperationException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InvalidOperationException extends TException implements org.apache.thrift.TBase<InvalidOperationException, InvalidOperationException._Fields>, java.io.Serializable, Cloneable, Comparable<InvalidOperationException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InvalidOperationException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class InvalidOperationException extends TException implements org.apache.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InvalidOperationException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InvalidOperationException typedOther = (InvalidOperationException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidPartitionException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidPartitionException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidPartitionException.java
index 99ffddb..e579563 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidPartitionException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/InvalidPartitionException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class InvalidPartitionException extends TException implements org.apache.thrift.TBase<InvalidPartitionException, InvalidPartitionException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class InvalidPartitionException extends TException implements org.apache.thrift.TBase<InvalidPartitionException, InvalidPartitionException._Fields>, java.io.Serializable, Cloneable, Comparable<InvalidPartitionException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("InvalidPartitionException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class InvalidPartitionException extends TException implements org.apache.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(InvalidPartitionException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    InvalidPartitionException typedOther = (InvalidPartitionException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockComponent.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockComponent.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockComponent.java
index 59c8199..6919642 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockComponent.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockComponent.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class LockComponent implements org.apache.thrift.TBase<LockComponent, LockComponent._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class LockComponent implements org.apache.thrift.TBase<LockComponent, LockComponent._Fields>, java.io.Serializable, Cloneable, Comparable<LockComponent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("LockComponent");
 
   private static final org.apache.thrift.protocol.TField TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("type", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -131,7 +135,7 @@ public class LockComponent implements org.apache.thrift.TBase<LockComponent, Loc
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.TABLENAME,_Fields.PARTITIONNAME};
+  private static final _Fields optionals[] = {_Fields.TABLENAME,_Fields.PARTITIONNAME};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -478,90 +482,90 @@ public class LockComponent implements org.apache.thrift.TBase<LockComponent, Loc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type.getValue());
+      list.add(type.getValue());
 
     boolean present_level = true && (isSetLevel());
-    builder.append(present_level);
+    list.add(present_level);
     if (present_level)
-      builder.append(level.getValue());
+      list.add(level.getValue());
 
     boolean present_dbname = true && (isSetDbname());
-    builder.append(present_dbname);
+    list.add(present_dbname);
     if (present_dbname)
-      builder.append(dbname);
+      list.add(dbname);
 
     boolean present_tablename = true && (isSetTablename());
-    builder.append(present_tablename);
+    list.add(present_tablename);
     if (present_tablename)
-      builder.append(tablename);
+      list.add(tablename);
 
     boolean present_partitionname = true && (isSetPartitionname());
-    builder.append(present_partitionname);
+    list.add(present_partitionname);
     if (present_partitionname)
-      builder.append(partitionname);
+      list.add(partitionname);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(LockComponent other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    LockComponent typedOther = (LockComponent)other;
 
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLevel()).compareTo(typedOther.isSetLevel());
+    lastComparison = Boolean.valueOf(isSetLevel()).compareTo(other.isSetLevel());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLevel()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.level, typedOther.level);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.level, other.level);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(typedOther.isSetDbname());
+    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(other.isSetDbname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, typedOther.dbname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, other.dbname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(typedOther.isSetTablename());
+    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(other.isSetTablename());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTablename()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, typedOther.tablename);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, other.tablename);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(typedOther.isSetPartitionname());
+    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(other.isSetPartitionname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, typedOther.partitionname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, other.partitionname);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -686,7 +690,7 @@ public class LockComponent implements org.apache.thrift.TBase<LockComponent, Loc
         switch (schemeField.id) {
           case 1: // TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.type = LockType.findByValue(iprot.readI32());
+              struct.type = org.apache.hadoop.hive.metastore.api.LockType.findByValue(iprot.readI32());
               struct.setTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -694,7 +698,7 @@ public class LockComponent implements org.apache.thrift.TBase<LockComponent, Loc
             break;
           case 2: // LEVEL
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.level = LockLevel.findByValue(iprot.readI32());
+              struct.level = org.apache.hadoop.hive.metastore.api.LockLevel.findByValue(iprot.readI32());
               struct.setLevelIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -805,9 +809,9 @@ public class LockComponent implements org.apache.thrift.TBase<LockComponent, Loc
     @Override
     public void read(org.apache.thrift.protocol.TProtocol prot, LockComponent struct) throws org.apache.thrift.TException {
       TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.type = LockType.findByValue(iprot.readI32());
+      struct.type = org.apache.hadoop.hive.metastore.api.LockType.findByValue(iprot.readI32());
       struct.setTypeIsSet(true);
-      struct.level = LockLevel.findByValue(iprot.readI32());
+      struct.level = org.apache.hadoop.hive.metastore.api.LockLevel.findByValue(iprot.readI32());
       struct.setLevelIsSet(true);
       struct.dbname = iprot.readString();
       struct.setDbnameIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockLevel.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockLevel.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockLevel.java
index ca5d30a..08840f1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockLevel.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockLevel.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java
index a5d8f9b..e370f09 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockRequest._Fields>, java.io.Serializable, Cloneable, Comparable<LockRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("LockRequest");
 
   private static final org.apache.thrift.protocol.TField COMPONENT_FIELD_DESC = new org.apache.thrift.protocol.TField("component", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -120,7 +124,7 @@ public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockReq
   // isset id assignments
   private static final int __TXNID_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.TXNID};
+  private static final _Fields optionals[] = {_Fields.TXNID};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -157,7 +161,7 @@ public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockReq
   public LockRequest(LockRequest other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetComponent()) {
-      List<LockComponent> __this__component = new ArrayList<LockComponent>();
+      List<LockComponent> __this__component = new ArrayList<LockComponent>(other.component.size());
       for (LockComponent other_element : other.component) {
         __this__component.add(new LockComponent(other_element));
       }
@@ -419,75 +423,75 @@ public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockReq
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_component = true && (isSetComponent());
-    builder.append(present_component);
+    list.add(present_component);
     if (present_component)
-      builder.append(component);
+      list.add(component);
 
     boolean present_txnid = true && (isSetTxnid());
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
     boolean present_user = true && (isSetUser());
-    builder.append(present_user);
+    list.add(present_user);
     if (present_user)
-      builder.append(user);
+      list.add(user);
 
     boolean present_hostname = true && (isSetHostname());
-    builder.append(present_hostname);
+    list.add(present_hostname);
     if (present_hostname)
-      builder.append(hostname);
+      list.add(hostname);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(LockRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    LockRequest typedOther = (LockRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetComponent()).compareTo(typedOther.isSetComponent());
+    lastComparison = Boolean.valueOf(isSetComponent()).compareTo(other.isSetComponent());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetComponent()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.component, typedOther.component);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.component, other.component);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUser()).compareTo(typedOther.isSetUser());
+    lastComparison = Boolean.valueOf(isSetUser()).compareTo(other.isSetUser());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUser()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, typedOther.user);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, other.user);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(typedOther.isSetHostname());
+    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(other.isSetHostname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHostname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, typedOther.hostname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, other.hostname);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -603,12 +607,12 @@ public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockReq
               {
                 org.apache.thrift.protocol.TList _list452 = iprot.readListBegin();
                 struct.component = new ArrayList<LockComponent>(_list452.size);
-                for (int _i453 = 0; _i453 < _list452.size; ++_i453)
+                LockComponent _elem453;
+                for (int _i454 = 0; _i454 < _list452.size; ++_i454)
                 {
-                  LockComponent _elem454; // optional
-                  _elem454 = new LockComponent();
-                  _elem454.read(iprot);
-                  struct.component.add(_elem454);
+                  _elem453 = new LockComponent();
+                  _elem453.read(iprot);
+                  struct.component.add(_elem453);
                 }
                 iprot.readListEnd();
               }
@@ -723,12 +727,12 @@ public class LockRequest implements org.apache.thrift.TBase<LockRequest, LockReq
       {
         org.apache.thrift.protocol.TList _list457 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.component = new ArrayList<LockComponent>(_list457.size);
-        for (int _i458 = 0; _i458 < _list457.size; ++_i458)
+        LockComponent _elem458;
+        for (int _i459 = 0; _i459 < _list457.size; ++_i459)
         {
-          LockComponent _elem459; // optional
-          _elem459 = new LockComponent();
-          _elem459.read(iprot);
-          struct.component.add(_elem459);
+          _elem458 = new LockComponent();
+          _elem458.read(iprot);
+          struct.component.add(_elem458);
         }
       }
       struct.setComponentIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockResponse.java
index c9ab465..faf0be7 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class LockResponse implements org.apache.thrift.TBase<LockResponse, LockResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class LockResponse implements org.apache.thrift.TBase<LockResponse, LockResponse._Fields>, java.io.Serializable, Cloneable, Comparable<LockResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("LockResponse");
 
   private static final org.apache.thrift.protocol.TField LOCKID_FIELD_DESC = new org.apache.thrift.protocol.TField("lockid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -297,45 +301,45 @@ public class LockResponse implements org.apache.thrift.TBase<LockResponse, LockR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lockid = true;
-    builder.append(present_lockid);
+    list.add(present_lockid);
     if (present_lockid)
-      builder.append(lockid);
+      list.add(lockid);
 
     boolean present_state = true && (isSetState());
-    builder.append(present_state);
+    list.add(present_state);
     if (present_state)
-      builder.append(state.getValue());
+      list.add(state.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(LockResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    LockResponse typedOther = (LockResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(typedOther.isSetLockid());
+    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(other.isSetLockid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLockid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, typedOther.lockid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, other.lockid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetState()).compareTo(typedOther.isSetState());
+    lastComparison = Boolean.valueOf(isSetState()).compareTo(other.isSetState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, typedOther.state);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, other.state);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -434,7 +438,7 @@ public class LockResponse implements org.apache.thrift.TBase<LockResponse, LockR
             break;
           case 2: // STATE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.state = LockState.findByValue(iprot.readI32());
+              struct.state = org.apache.hadoop.hive.metastore.api.LockState.findByValue(iprot.readI32());
               struct.setStateIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -487,7 +491,7 @@ public class LockResponse implements org.apache.thrift.TBase<LockResponse, LockR
       TTupleProtocol iprot = (TTupleProtocol) prot;
       struct.lockid = iprot.readI64();
       struct.setLockidIsSet(true);
-      struct.state = LockState.findByValue(iprot.readI32());
+      struct.state = org.apache.hadoop.hive.metastore.api.LockState.findByValue(iprot.readI32());
       struct.setStateIsSet(true);
     }
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockState.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockState.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockState.java
index 57bc3c5..bce2b5a 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockState.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockState.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockType.java
index ee57883..9d60531 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LongColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LongColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LongColumnStatsData.java
index d817d46..a6f076d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LongColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LongColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class LongColumnStatsData implements org.apache.thrift.TBase<LongColumnStatsData, LongColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class LongColumnStatsData implements org.apache.thrift.TBase<LongColumnStatsData, LongColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<LongColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("LongColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField LOW_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("lowValue", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -123,7 +127,7 @@ public class LongColumnStatsData implements org.apache.thrift.TBase<LongColumnSt
   private static final int __NUMNULLS_ISSET_ID = 2;
   private static final int __NUMDVS_ISSET_ID = 3;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
+  private static final _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -396,75 +400,75 @@ public class LongColumnStatsData implements org.apache.thrift.TBase<LongColumnSt
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lowValue = true && (isSetLowValue());
-    builder.append(present_lowValue);
+    list.add(present_lowValue);
     if (present_lowValue)
-      builder.append(lowValue);
+      list.add(lowValue);
 
     boolean present_highValue = true && (isSetHighValue());
-    builder.append(present_highValue);
+    list.add(present_highValue);
     if (present_highValue)
-      builder.append(highValue);
+      list.add(highValue);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
     boolean present_numDVs = true;
-    builder.append(present_numDVs);
+    list.add(present_numDVs);
     if (present_numDVs)
-      builder.append(numDVs);
+      list.add(numDVs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(LongColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    LongColumnStatsData typedOther = (LongColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(typedOther.isSetLowValue());
+    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(other.isSetLowValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLowValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, typedOther.lowValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, other.lowValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(typedOther.isSetHighValue());
+    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(other.isSetHighValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHighValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, typedOther.highValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, other.highValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(typedOther.isSetNumDVs());
+    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(other.isSetNumDVs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumDVs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, typedOther.numDVs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, other.numDVs);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/MetaException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/MetaException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/MetaException.java
index 108bca9..57222b7 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/MetaException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/MetaException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class MetaException extends TException implements org.apache.thrift.TBase<MetaException, MetaException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class MetaException extends TException implements org.apache.thrift.TBase<MetaException, MetaException._Fields>, java.io.Serializable, Cloneable, Comparable<MetaException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MetaException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class MetaException extends TException implements org.apache.thrift.TBase
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(MetaException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    MetaException typedOther = (MetaException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchLockException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchLockException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchLockException.java
index 9c8bd0b..0dcd16d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchLockException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchLockException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NoSuchLockException extends TException implements org.apache.thrift.TBase<NoSuchLockException, NoSuchLockException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NoSuchLockException extends TException implements org.apache.thrift.TBase<NoSuchLockException, NoSuchLockException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchLockException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchLockException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class NoSuchLockException extends TException implements org.apache.thrift
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NoSuchLockException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NoSuchLockException typedOther = (NoSuchLockException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchObjectException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchObjectException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchObjectException.java
index 305e979..5575a36 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchObjectException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchObjectException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NoSuchObjectException extends TException implements org.apache.thrift.TBase<NoSuchObjectException, NoSuchObjectException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NoSuchObjectException extends TException implements org.apache.thrift.TBase<NoSuchObjectException, NoSuchObjectException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchObjectException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchObjectException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class NoSuchObjectException extends TException implements org.apache.thri
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NoSuchObjectException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NoSuchObjectException typedOther = (NoSuchObjectException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchTxnException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchTxnException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchTxnException.java
index 92dbb7f..4af695c 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchTxnException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NoSuchTxnException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NoSuchTxnException extends TException implements org.apache.thrift.TBase<NoSuchTxnException, NoSuchTxnException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NoSuchTxnException extends TException implements org.apache.thrift.TBase<NoSuchTxnException, NoSuchTxnException._Fields>, java.io.Serializable, Cloneable, Comparable<NoSuchTxnException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NoSuchTxnException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class NoSuchTxnException extends TException implements org.apache.thrift.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NoSuchTxnException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NoSuchTxnException typedOther = (NoSuchTxnException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEvent.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEvent.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEvent.java
index f196c1c..a487617 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEvent.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEvent.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NotificationEvent implements org.apache.thrift.TBase<NotificationEvent, NotificationEvent._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NotificationEvent implements org.apache.thrift.TBase<NotificationEvent, NotificationEvent._Fields>, java.io.Serializable, Cloneable, Comparable<NotificationEvent> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotificationEvent");
 
   private static final org.apache.thrift.protocol.TField EVENT_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("eventId", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -131,7 +135,7 @@ public class NotificationEvent implements org.apache.thrift.TBase<NotificationEv
   private static final int __EVENTID_ISSET_ID = 0;
   private static final int __EVENTTIME_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.DB_NAME,_Fields.TABLE_NAME};
+  private static final _Fields optionals[] = {_Fields.DB_NAME,_Fields.TABLE_NAME};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -514,105 +518,105 @@ public class NotificationEvent implements org.apache.thrift.TBase<NotificationEv
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_eventId = true;
-    builder.append(present_eventId);
+    list.add(present_eventId);
     if (present_eventId)
-      builder.append(eventId);
+      list.add(eventId);
 
     boolean present_eventTime = true;
-    builder.append(present_eventTime);
+    list.add(present_eventTime);
     if (present_eventTime)
-      builder.append(eventTime);
+      list.add(eventTime);
 
     boolean present_eventType = true && (isSetEventType());
-    builder.append(present_eventType);
+    list.add(present_eventType);
     if (present_eventType)
-      builder.append(eventType);
+      list.add(eventType);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NotificationEvent other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NotificationEvent typedOther = (NotificationEvent)other;
 
-    lastComparison = Boolean.valueOf(isSetEventId()).compareTo(typedOther.isSetEventId());
+    lastComparison = Boolean.valueOf(isSetEventId()).compareTo(other.isSetEventId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEventId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventId, typedOther.eventId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventId, other.eventId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetEventTime()).compareTo(typedOther.isSetEventTime());
+    lastComparison = Boolean.valueOf(isSetEventTime()).compareTo(other.isSetEventTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEventTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventTime, typedOther.eventTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventTime, other.eventTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetEventType()).compareTo(typedOther.isSetEventType());
+    lastComparison = Boolean.valueOf(isSetEventType()).compareTo(other.isSetEventType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEventType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventType, typedOther.eventType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventType, other.eventType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventRequest.java
index 6a8c8ab..c42c069 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/NotificationEventRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class NotificationEventRequest implements org.apache.thrift.TBase<NotificationEventRequest, NotificationEventRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class NotificationEventRequest implements org.apache.thrift.TBase<NotificationEventRequest, NotificationEventRequest._Fields>, java.io.Serializable, Cloneable, Comparable<NotificationEventRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("NotificationEventRequest");
 
   private static final org.apache.thrift.protocol.TField LAST_EVENT_FIELD_DESC = new org.apache.thrift.protocol.TField("lastEvent", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -111,7 +115,7 @@ public class NotificationEventRequest implements org.apache.thrift.TBase<Notific
   private static final int __LASTEVENT_ISSET_ID = 0;
   private static final int __MAXEVENTS_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.MAX_EVENTS};
+  private static final _Fields optionals[] = {_Fields.MAX_EVENTS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -283,45 +287,45 @@ public class NotificationEventRequest implements org.apache.thrift.TBase<Notific
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lastEvent = true;
-    builder.append(present_lastEvent);
+    list.add(present_lastEvent);
     if (present_lastEvent)
-      builder.append(lastEvent);
+      list.add(lastEvent);
 
     boolean present_maxEvents = true && (isSetMaxEvents());
-    builder.append(present_maxEvents);
+    list.add(present_maxEvents);
     if (present_maxEvents)
-      builder.append(maxEvents);
+      list.add(maxEvents);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(NotificationEventRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    NotificationEventRequest typedOther = (NotificationEventRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetLastEvent()).compareTo(typedOther.isSetLastEvent());
+    lastComparison = Boolean.valueOf(isSetLastEvent()).compareTo(other.isSetLastEvent());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastEvent()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastEvent, typedOther.lastEvent);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastEvent, other.lastEvent);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMaxEvents()).compareTo(typedOther.isSetMaxEvents());
+    lastComparison = Boolean.valueOf(isSetMaxEvents()).compareTo(other.isSetMaxEvents());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxEvents()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxEvents, typedOther.maxEvents);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxEvents, other.maxEvents);
       if (lastComparison != 0) {
         return lastComparison;
       }


[35/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RolePrincipalGrant.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RolePrincipalGrant.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RolePrincipalGrant.java
index 8993268..c23a265 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RolePrincipalGrant.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RolePrincipalGrant.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipalGrant, RolePrincipalGrant._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipalGrant, RolePrincipalGrant._Fields>, java.io.Serializable, Cloneable, Comparable<RolePrincipalGrant> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RolePrincipalGrant");
 
   private static final org.apache.thrift.protocol.TField ROLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("roleName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -599,120 +603,120 @@ public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipal
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_roleName = true && (isSetRoleName());
-    builder.append(present_roleName);
+    list.add(present_roleName);
     if (present_roleName)
-      builder.append(roleName);
+      list.add(roleName);
 
     boolean present_principalName = true && (isSetPrincipalName());
-    builder.append(present_principalName);
+    list.add(present_principalName);
     if (present_principalName)
-      builder.append(principalName);
+      list.add(principalName);
 
     boolean present_principalType = true && (isSetPrincipalType());
-    builder.append(present_principalType);
+    list.add(present_principalType);
     if (present_principalType)
-      builder.append(principalType.getValue());
+      list.add(principalType.getValue());
 
     boolean present_grantOption = true;
-    builder.append(present_grantOption);
+    list.add(present_grantOption);
     if (present_grantOption)
-      builder.append(grantOption);
+      list.add(grantOption);
 
     boolean present_grantTime = true;
-    builder.append(present_grantTime);
+    list.add(present_grantTime);
     if (present_grantTime)
-      builder.append(grantTime);
+      list.add(grantTime);
 
     boolean present_grantorName = true && (isSetGrantorName());
-    builder.append(present_grantorName);
+    list.add(present_grantorName);
     if (present_grantorName)
-      builder.append(grantorName);
+      list.add(grantorName);
 
     boolean present_grantorPrincipalType = true && (isSetGrantorPrincipalType());
-    builder.append(present_grantorPrincipalType);
+    list.add(present_grantorPrincipalType);
     if (present_grantorPrincipalType)
-      builder.append(grantorPrincipalType.getValue());
+      list.add(grantorPrincipalType.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(RolePrincipalGrant other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    RolePrincipalGrant typedOther = (RolePrincipalGrant)other;
 
-    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(typedOther.isSetRoleName());
+    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(other.isSetRoleName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRoleName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, typedOther.roleName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, other.roleName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(typedOther.isSetPrincipalName());
+    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(other.isSetPrincipalName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, typedOther.principalName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, other.principalName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(typedOther.isSetPrincipalType());
+    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(other.isSetPrincipalType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, typedOther.principalType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, other.principalType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(typedOther.isSetGrantOption());
+    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(other.isSetGrantOption());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantOption()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, typedOther.grantOption);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, other.grantOption);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantTime()).compareTo(typedOther.isSetGrantTime());
+    lastComparison = Boolean.valueOf(isSetGrantTime()).compareTo(other.isSetGrantTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantTime, typedOther.grantTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantTime, other.grantTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantorName()).compareTo(typedOther.isSetGrantorName());
+    lastComparison = Boolean.valueOf(isSetGrantorName()).compareTo(other.isSetGrantorName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantorName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorName, typedOther.grantorName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorName, other.grantorName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantorPrincipalType()).compareTo(typedOther.isSetGrantorPrincipalType());
+    lastComparison = Boolean.valueOf(isSetGrantorPrincipalType()).compareTo(other.isSetGrantorPrincipalType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantorPrincipalType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorPrincipalType, typedOther.grantorPrincipalType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorPrincipalType, other.grantorPrincipalType);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -847,7 +851,7 @@ public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipal
             break;
           case 3: // PRINCIPAL_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.principalType = PrincipalType.findByValue(iprot.readI32());
+              struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setPrincipalTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -879,7 +883,7 @@ public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipal
             break;
           case 7: // GRANTOR_PRINCIPAL_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.grantorPrincipalType = PrincipalType.findByValue(iprot.readI32());
+              struct.grantorPrincipalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setGrantorPrincipalTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1005,7 +1009,7 @@ public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipal
         struct.setPrincipalNameIsSet(true);
       }
       if (incoming.get(2)) {
-        struct.principalType = PrincipalType.findByValue(iprot.readI32());
+        struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setPrincipalTypeIsSet(true);
       }
       if (incoming.get(3)) {
@@ -1021,7 +1025,7 @@ public class RolePrincipalGrant implements org.apache.thrift.TBase<RolePrincipal
         struct.setGrantorNameIsSet(true);
       }
       if (incoming.get(6)) {
-        struct.grantorPrincipalType = PrincipalType.findByValue(iprot.readI32());
+        struct.grantorPrincipalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setGrantorPrincipalTypeIsSet(true);
       }
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Schema.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Schema.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Schema.java
index 31ee943..8ee63cb 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Schema.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Schema.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>, java.io.Serializable, Cloneable, Comparable<Schema> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Schema");
 
   private static final org.apache.thrift.protocol.TField FIELD_SCHEMAS_FIELD_DESC = new org.apache.thrift.protocol.TField("fieldSchemas", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -139,25 +143,14 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
    */
   public Schema(Schema other) {
     if (other.isSetFieldSchemas()) {
-      List<FieldSchema> __this__fieldSchemas = new ArrayList<FieldSchema>();
+      List<FieldSchema> __this__fieldSchemas = new ArrayList<FieldSchema>(other.fieldSchemas.size());
       for (FieldSchema other_element : other.fieldSchemas) {
         __this__fieldSchemas.add(new FieldSchema(other_element));
       }
       this.fieldSchemas = __this__fieldSchemas;
     }
     if (other.isSetProperties()) {
-      Map<String,String> __this__properties = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.properties.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__properties_copy_key = other_element_key;
-
-        String __this__properties_copy_value = other_element_value;
-
-        __this__properties.put(__this__properties_copy_key, __this__properties_copy_value);
-      }
+      Map<String,String> __this__properties = new HashMap<String,String>(other.properties);
       this.properties = __this__properties;
     }
   }
@@ -328,45 +321,45 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_fieldSchemas = true && (isSetFieldSchemas());
-    builder.append(present_fieldSchemas);
+    list.add(present_fieldSchemas);
     if (present_fieldSchemas)
-      builder.append(fieldSchemas);
+      list.add(fieldSchemas);
 
     boolean present_properties = true && (isSetProperties());
-    builder.append(present_properties);
+    list.add(present_properties);
     if (present_properties)
-      builder.append(properties);
+      list.add(properties);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Schema other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Schema typedOther = (Schema)other;
 
-    lastComparison = Boolean.valueOf(isSetFieldSchemas()).compareTo(typedOther.isSetFieldSchemas());
+    lastComparison = Boolean.valueOf(isSetFieldSchemas()).compareTo(other.isSetFieldSchemas());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFieldSchemas()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fieldSchemas, typedOther.fieldSchemas);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fieldSchemas, other.fieldSchemas);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetProperties()).compareTo(typedOther.isSetProperties());
+    lastComparison = Boolean.valueOf(isSetProperties()).compareTo(other.isSetProperties());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetProperties()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.properties, typedOther.properties);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.properties, other.properties);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -454,12 +447,12 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
               {
                 org.apache.thrift.protocol.TList _list294 = iprot.readListBegin();
                 struct.fieldSchemas = new ArrayList<FieldSchema>(_list294.size);
-                for (int _i295 = 0; _i295 < _list294.size; ++_i295)
+                FieldSchema _elem295;
+                for (int _i296 = 0; _i296 < _list294.size; ++_i296)
                 {
-                  FieldSchema _elem296; // optional
-                  _elem296 = new FieldSchema();
-                  _elem296.read(iprot);
-                  struct.fieldSchemas.add(_elem296);
+                  _elem295 = new FieldSchema();
+                  _elem295.read(iprot);
+                  struct.fieldSchemas.add(_elem295);
                 }
                 iprot.readListEnd();
               }
@@ -473,13 +466,13 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
               {
                 org.apache.thrift.protocol.TMap _map297 = iprot.readMapBegin();
                 struct.properties = new HashMap<String,String>(2*_map297.size);
-                for (int _i298 = 0; _i298 < _map297.size; ++_i298)
+                String _key298;
+                String _val299;
+                for (int _i300 = 0; _i300 < _map297.size; ++_i300)
                 {
-                  String _key299; // required
-                  String _val300; // required
-                  _key299 = iprot.readString();
-                  _val300 = iprot.readString();
-                  struct.properties.put(_key299, _val300);
+                  _key298 = iprot.readString();
+                  _val299 = iprot.readString();
+                  struct.properties.put(_key298, _val299);
                 }
                 iprot.readMapEnd();
               }
@@ -580,12 +573,12 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
         {
           org.apache.thrift.protocol.TList _list305 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.fieldSchemas = new ArrayList<FieldSchema>(_list305.size);
-          for (int _i306 = 0; _i306 < _list305.size; ++_i306)
+          FieldSchema _elem306;
+          for (int _i307 = 0; _i307 < _list305.size; ++_i307)
           {
-            FieldSchema _elem307; // optional
-            _elem307 = new FieldSchema();
-            _elem307.read(iprot);
-            struct.fieldSchemas.add(_elem307);
+            _elem306 = new FieldSchema();
+            _elem306.read(iprot);
+            struct.fieldSchemas.add(_elem306);
           }
         }
         struct.setFieldSchemasIsSet(true);
@@ -594,13 +587,13 @@ public class Schema implements org.apache.thrift.TBase<Schema, Schema._Fields>,
         {
           org.apache.thrift.protocol.TMap _map308 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.properties = new HashMap<String,String>(2*_map308.size);
-          for (int _i309 = 0; _i309 < _map308.size; ++_i309)
+          String _key309;
+          String _val310;
+          for (int _i311 = 0; _i311 < _map308.size; ++_i311)
           {
-            String _key310; // required
-            String _val311; // required
-            _key310 = iprot.readString();
-            _val311 = iprot.readString();
-            struct.properties.put(_key310, _val311);
+            _key309 = iprot.readString();
+            _val310 = iprot.readString();
+            struct.properties.put(_key309, _val310);
           }
         }
         struct.setPropertiesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SerDeInfo.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SerDeInfo.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SerDeInfo.java
index 24d65bb..b3bfe5d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SerDeInfo.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SerDeInfo.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._Fields>, java.io.Serializable, Cloneable, Comparable<SerDeInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("SerDeInfo");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -137,9 +141,9 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
     Map<String,String> parameters)
   {
     this();
-    this.name = name;
-    this.serializationLib = serializationLib;
-    this.parameters = parameters;
+    this.name = org.apache.hive.common.util.HiveStringUtils.intern(name);
+    this.serializationLib = org.apache.hive.common.util.HiveStringUtils.intern(serializationLib);
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   /**
@@ -147,24 +151,13 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
    */
   public SerDeInfo(SerDeInfo other) {
     if (other.isSetName()) {
-      this.name = other.name;
+      this.name = org.apache.hive.common.util.HiveStringUtils.intern(other.name);
     }
     if (other.isSetSerializationLib()) {
-      this.serializationLib = other.serializationLib;
+      this.serializationLib = org.apache.hive.common.util.HiveStringUtils.intern(other.serializationLib);
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
   }
@@ -185,7 +178,7 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
   }
 
   public void setName(String name) {
-    this.name = name;
+    this.name = org.apache.hive.common.util.HiveStringUtils.intern(name);
   }
 
   public void unsetName() {
@@ -208,7 +201,7 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
   }
 
   public void setSerializationLib(String serializationLib) {
-    this.serializationLib = serializationLib;
+    this.serializationLib = org.apache.hive.common.util.HiveStringUtils.intern(serializationLib);
   }
 
   public void unsetSerializationLib() {
@@ -242,7 +235,7 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
   }
 
   public void setParameters(Map<String,String> parameters) {
-    this.parameters = parameters;
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   public void unsetParameters() {
@@ -366,60 +359,60 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_name = true && (isSetName());
-    builder.append(present_name);
+    list.add(present_name);
     if (present_name)
-      builder.append(name);
+      list.add(name);
 
     boolean present_serializationLib = true && (isSetSerializationLib());
-    builder.append(present_serializationLib);
+    list.add(present_serializationLib);
     if (present_serializationLib)
-      builder.append(serializationLib);
+      list.add(serializationLib);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(SerDeInfo other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    SerDeInfo typedOther = (SerDeInfo)other;
 
-    lastComparison = Boolean.valueOf(isSetName()).compareTo(typedOther.isSetName());
+    lastComparison = Boolean.valueOf(isSetName()).compareTo(other.isSetName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, typedOther.name);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, other.name);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSerializationLib()).compareTo(typedOther.isSetSerializationLib());
+    lastComparison = Boolean.valueOf(isSetSerializationLib()).compareTo(other.isSetSerializationLib());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSerializationLib()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serializationLib, typedOther.serializationLib);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serializationLib, other.serializationLib);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -531,13 +524,13 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
               {
                 org.apache.thrift.protocol.TMap _map104 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map104.size);
-                for (int _i105 = 0; _i105 < _map104.size; ++_i105)
+                String _key105;
+                String _val106;
+                for (int _i107 = 0; _i107 < _map104.size; ++_i107)
                 {
-                  String _key106; // required
-                  String _val107; // required
-                  _key106 = iprot.readString();
-                  _val107 = iprot.readString();
-                  struct.parameters.put(_key106, _val107);
+                  _key105 = iprot.readString();
+                  _val106 = iprot.readString();
+                  struct.parameters.put(_key105, _val106);
                 }
                 iprot.readMapEnd();
               }
@@ -644,13 +637,13 @@ public class SerDeInfo implements org.apache.thrift.TBase<SerDeInfo, SerDeInfo._
         {
           org.apache.thrift.protocol.TMap _map110 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map110.size);
-          for (int _i111 = 0; _i111 < _map110.size; ++_i111)
+          String _key111;
+          String _val112;
+          for (int _i113 = 0; _i113 < _map110.size; ++_i113)
           {
-            String _key112; // required
-            String _val113; // required
-            _key112 = iprot.readString();
-            _val113 = iprot.readString();
-            struct.parameters.put(_key112, _val113);
+            _key111 = iprot.readString();
+            _val112 = iprot.readString();
+            struct.parameters.put(_key111, _val112);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SetPartitionsStatsRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SetPartitionsStatsRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SetPartitionsStatsRequest.java
index e62e410..13157ce 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SetPartitionsStatsRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SetPartitionsStatsRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPartitionsStatsRequest, SetPartitionsStatsRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPartitionsStatsRequest, SetPartitionsStatsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<SetPartitionsStatsRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("SetPartitionsStatsRequest");
 
   private static final org.apache.thrift.protocol.TField COL_STATS_FIELD_DESC = new org.apache.thrift.protocol.TField("colStats", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPar
    */
   public SetPartitionsStatsRequest(SetPartitionsStatsRequest other) {
     if (other.isSetColStats()) {
-      List<ColumnStatistics> __this__colStats = new ArrayList<ColumnStatistics>();
+      List<ColumnStatistics> __this__colStats = new ArrayList<ColumnStatistics>(other.colStats.size());
       for (ColumnStatistics other_element : other.colStats) {
         __this__colStats.add(new ColumnStatistics(other_element));
       }
@@ -245,30 +249,30 @@ public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPar
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_colStats = true && (isSetColStats());
-    builder.append(present_colStats);
+    list.add(present_colStats);
     if (present_colStats)
-      builder.append(colStats);
+      list.add(colStats);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(SetPartitionsStatsRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    SetPartitionsStatsRequest typedOther = (SetPartitionsStatsRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetColStats()).compareTo(typedOther.isSetColStats());
+    lastComparison = Boolean.valueOf(isSetColStats()).compareTo(other.isSetColStats());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColStats()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colStats, typedOther.colStats);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colStats, other.colStats);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPar
               {
                 org.apache.thrift.protocol.TList _list286 = iprot.readListBegin();
                 struct.colStats = new ArrayList<ColumnStatistics>(_list286.size);
-                for (int _i287 = 0; _i287 < _list286.size; ++_i287)
+                ColumnStatistics _elem287;
+                for (int _i288 = 0; _i288 < _list286.size; ++_i288)
                 {
-                  ColumnStatistics _elem288; // optional
-                  _elem288 = new ColumnStatistics();
-                  _elem288.read(iprot);
-                  struct.colStats.add(_elem288);
+                  _elem287 = new ColumnStatistics();
+                  _elem287.read(iprot);
+                  struct.colStats.add(_elem287);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class SetPartitionsStatsRequest implements org.apache.thrift.TBase<SetPar
       {
         org.apache.thrift.protocol.TList _list291 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.colStats = new ArrayList<ColumnStatistics>(_list291.size);
-        for (int _i292 = 0; _i292 < _list291.size; ++_i292)
+        ColumnStatistics _elem292;
+        for (int _i293 = 0; _i293 < _list291.size; ++_i293)
         {
-          ColumnStatistics _elem293; // optional
-          _elem293 = new ColumnStatistics();
-          _elem293.read(iprot);
-          struct.colStats.add(_elem293);
+          _elem292 = new ColumnStatistics();
+          _elem292.read(iprot);
+          struct.colStats.add(_elem292);
         }
       }
       struct.setColStatsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactRequest.java
index 28ad1c9..a40a04d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowCompactRequest implements org.apache.thrift.TBase<ShowCompactRequest, ShowCompactRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowCompactRequest implements org.apache.thrift.TBase<ShowCompactRequest, ShowCompactRequest._Fields>, java.io.Serializable, Cloneable, Comparable<ShowCompactRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowCompactRequest");
 
 
@@ -161,18 +165,18 @@ public class ShowCompactRequest implements org.apache.thrift.TBase<ShowCompactRe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowCompactRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowCompactRequest typedOther = (ShowCompactRequest)other;
 
     return 0;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponse.java
index c882b7b..617cff6 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactResponse, ShowCompactResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactResponse, ShowCompactResponse._Fields>, java.io.Serializable, Cloneable, Comparable<ShowCompactResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowCompactResponse");
 
   private static final org.apache.thrift.protocol.TField COMPACTS_FIELD_DESC = new org.apache.thrift.protocol.TField("compacts", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactR
    */
   public ShowCompactResponse(ShowCompactResponse other) {
     if (other.isSetCompacts()) {
-      List<ShowCompactResponseElement> __this__compacts = new ArrayList<ShowCompactResponseElement>();
+      List<ShowCompactResponseElement> __this__compacts = new ArrayList<ShowCompactResponseElement>(other.compacts.size());
       for (ShowCompactResponseElement other_element : other.compacts) {
         __this__compacts.add(new ShowCompactResponseElement(other_element));
       }
@@ -245,30 +249,30 @@ public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_compacts = true && (isSetCompacts());
-    builder.append(present_compacts);
+    list.add(present_compacts);
     if (present_compacts)
-      builder.append(compacts);
+      list.add(compacts);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowCompactResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowCompactResponse typedOther = (ShowCompactResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetCompacts()).compareTo(typedOther.isSetCompacts());
+    lastComparison = Boolean.valueOf(isSetCompacts()).compareTo(other.isSetCompacts());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCompacts()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.compacts, typedOther.compacts);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.compacts, other.compacts);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactR
               {
                 org.apache.thrift.protocol.TList _list484 = iprot.readListBegin();
                 struct.compacts = new ArrayList<ShowCompactResponseElement>(_list484.size);
-                for (int _i485 = 0; _i485 < _list484.size; ++_i485)
+                ShowCompactResponseElement _elem485;
+                for (int _i486 = 0; _i486 < _list484.size; ++_i486)
                 {
-                  ShowCompactResponseElement _elem486; // optional
-                  _elem486 = new ShowCompactResponseElement();
-                  _elem486.read(iprot);
-                  struct.compacts.add(_elem486);
+                  _elem485 = new ShowCompactResponseElement();
+                  _elem485.read(iprot);
+                  struct.compacts.add(_elem485);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class ShowCompactResponse implements org.apache.thrift.TBase<ShowCompactR
       {
         org.apache.thrift.protocol.TList _list489 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.compacts = new ArrayList<ShowCompactResponseElement>(_list489.size);
-        for (int _i490 = 0; _i490 < _list489.size; ++_i490)
+        ShowCompactResponseElement _elem490;
+        for (int _i491 = 0; _i491 < _list489.size; ++_i491)
         {
-          ShowCompactResponseElement _elem491; // optional
-          _elem491 = new ShowCompactResponseElement();
-          _elem491.read(iprot);
-          struct.compacts.add(_elem491);
+          _elem490 = new ShowCompactResponseElement();
+          _elem490.read(iprot);
+          struct.compacts.add(_elem490);
         }
       }
       struct.setCompactsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponseElement.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponseElement.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponseElement.java
index 365a401..308783b 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponseElement.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowCompactResponseElement.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowCompactResponseElement, ShowCompactResponseElement._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowCompactResponseElement, ShowCompactResponseElement._Fields>, java.io.Serializable, Cloneable, Comparable<ShowCompactResponseElement> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowCompactResponseElement");
 
   private static final org.apache.thrift.protocol.TField DBNAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbname", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -144,7 +148,7 @@ public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowC
   // isset id assignments
   private static final int __START_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PARTITIONNAME,_Fields.WORKERID,_Fields.START,_Fields.RUN_AS};
+  private static final _Fields optionals[] = {_Fields.PARTITIONNAME,_Fields.WORKERID,_Fields.START,_Fields.RUN_AS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -637,135 +641,135 @@ public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowC
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbname = true && (isSetDbname());
-    builder.append(present_dbname);
+    list.add(present_dbname);
     if (present_dbname)
-      builder.append(dbname);
+      list.add(dbname);
 
     boolean present_tablename = true && (isSetTablename());
-    builder.append(present_tablename);
+    list.add(present_tablename);
     if (present_tablename)
-      builder.append(tablename);
+      list.add(tablename);
 
     boolean present_partitionname = true && (isSetPartitionname());
-    builder.append(present_partitionname);
+    list.add(present_partitionname);
     if (present_partitionname)
-      builder.append(partitionname);
+      list.add(partitionname);
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type.getValue());
+      list.add(type.getValue());
 
     boolean present_state = true && (isSetState());
-    builder.append(present_state);
+    list.add(present_state);
     if (present_state)
-      builder.append(state);
+      list.add(state);
 
     boolean present_workerid = true && (isSetWorkerid());
-    builder.append(present_workerid);
+    list.add(present_workerid);
     if (present_workerid)
-      builder.append(workerid);
+      list.add(workerid);
 
     boolean present_start = true && (isSetStart());
-    builder.append(present_start);
+    list.add(present_start);
     if (present_start)
-      builder.append(start);
+      list.add(start);
 
     boolean present_runAs = true && (isSetRunAs());
-    builder.append(present_runAs);
+    list.add(present_runAs);
     if (present_runAs)
-      builder.append(runAs);
+      list.add(runAs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowCompactResponseElement other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowCompactResponseElement typedOther = (ShowCompactResponseElement)other;
 
-    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(typedOther.isSetDbname());
+    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(other.isSetDbname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, typedOther.dbname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, other.dbname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(typedOther.isSetTablename());
+    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(other.isSetTablename());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTablename()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, typedOther.tablename);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, other.tablename);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(typedOther.isSetPartitionname());
+    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(other.isSetPartitionname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, typedOther.partitionname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, other.partitionname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetState()).compareTo(typedOther.isSetState());
+    lastComparison = Boolean.valueOf(isSetState()).compareTo(other.isSetState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, typedOther.state);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, other.state);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetWorkerid()).compareTo(typedOther.isSetWorkerid());
+    lastComparison = Boolean.valueOf(isSetWorkerid()).compareTo(other.isSetWorkerid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetWorkerid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.workerid, typedOther.workerid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.workerid, other.workerid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStart()).compareTo(typedOther.isSetStart());
+    lastComparison = Boolean.valueOf(isSetStart()).compareTo(other.isSetStart());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStart()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.start, typedOther.start);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.start, other.start);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRunAs()).compareTo(typedOther.isSetRunAs());
+    lastComparison = Boolean.valueOf(isSetRunAs()).compareTo(other.isSetRunAs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRunAs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runAs, typedOther.runAs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runAs, other.runAs);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -944,7 +948,7 @@ public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowC
             break;
           case 4: // TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.type = CompactionType.findByValue(iprot.readI32());
+              struct.type = org.apache.hadoop.hive.metastore.api.CompactionType.findByValue(iprot.readI32());
               struct.setTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1097,7 +1101,7 @@ public class ShowCompactResponseElement implements org.apache.thrift.TBase<ShowC
       struct.setDbnameIsSet(true);
       struct.tablename = iprot.readString();
       struct.setTablenameIsSet(true);
-      struct.type = CompactionType.findByValue(iprot.readI32());
+      struct.type = org.apache.hadoop.hive.metastore.api.CompactionType.findByValue(iprot.readI32());
       struct.setTypeIsSet(true);
       struct.state = iprot.readString();
       struct.setStateIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksRequest.java
index 7a1fd6f..0cd2c73 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowLocksRequest implements org.apache.thrift.TBase<ShowLocksRequest, ShowLocksRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowLocksRequest implements org.apache.thrift.TBase<ShowLocksRequest, ShowLocksRequest._Fields>, java.io.Serializable, Cloneable, Comparable<ShowLocksRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowLocksRequest");
 
 
@@ -161,18 +165,18 @@ public class ShowLocksRequest implements org.apache.thrift.TBase<ShowLocksReques
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowLocksRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowLocksRequest typedOther = (ShowLocksRequest)other;
 
     return 0;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponse.java
index 42cfe8c..aec38b2 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksResponse, ShowLocksResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksResponse, ShowLocksResponse._Fields>, java.io.Serializable, Cloneable, Comparable<ShowLocksResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowLocksResponse");
 
   private static final org.apache.thrift.protocol.TField LOCKS_FIELD_DESC = new org.apache.thrift.protocol.TField("locks", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksRespo
    */
   public ShowLocksResponse(ShowLocksResponse other) {
     if (other.isSetLocks()) {
-      List<ShowLocksResponseElement> __this__locks = new ArrayList<ShowLocksResponseElement>();
+      List<ShowLocksResponseElement> __this__locks = new ArrayList<ShowLocksResponseElement>(other.locks.size());
       for (ShowLocksResponseElement other_element : other.locks) {
         __this__locks.add(new ShowLocksResponseElement(other_element));
       }
@@ -245,30 +249,30 @@ public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksRespo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_locks = true && (isSetLocks());
-    builder.append(present_locks);
+    list.add(present_locks);
     if (present_locks)
-      builder.append(locks);
+      list.add(locks);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowLocksResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowLocksResponse typedOther = (ShowLocksResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetLocks()).compareTo(typedOther.isSetLocks());
+    lastComparison = Boolean.valueOf(isSetLocks()).compareTo(other.isSetLocks());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLocks()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.locks, typedOther.locks);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.locks, other.locks);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -348,12 +352,12 @@ public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksRespo
               {
                 org.apache.thrift.protocol.TList _list460 = iprot.readListBegin();
                 struct.locks = new ArrayList<ShowLocksResponseElement>(_list460.size);
-                for (int _i461 = 0; _i461 < _list460.size; ++_i461)
+                ShowLocksResponseElement _elem461;
+                for (int _i462 = 0; _i462 < _list460.size; ++_i462)
                 {
-                  ShowLocksResponseElement _elem462; // optional
-                  _elem462 = new ShowLocksResponseElement();
-                  _elem462.read(iprot);
-                  struct.locks.add(_elem462);
+                  _elem461 = new ShowLocksResponseElement();
+                  _elem461.read(iprot);
+                  struct.locks.add(_elem461);
                 }
                 iprot.readListEnd();
               }
@@ -428,12 +432,12 @@ public class ShowLocksResponse implements org.apache.thrift.TBase<ShowLocksRespo
         {
           org.apache.thrift.protocol.TList _list465 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.locks = new ArrayList<ShowLocksResponseElement>(_list465.size);
-          for (int _i466 = 0; _i466 < _list465.size; ++_i466)
+          ShowLocksResponseElement _elem466;
+          for (int _i467 = 0; _i467 < _list465.size; ++_i467)
           {
-            ShowLocksResponseElement _elem467; // optional
-            _elem467 = new ShowLocksResponseElement();
-            _elem467.read(iprot);
-            struct.locks.add(_elem467);
+            _elem466 = new ShowLocksResponseElement();
+            _elem466.read(iprot);
+            struct.locks.add(_elem466);
           }
         }
         struct.setLocksIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponseElement.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponseElement.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponseElement.java
index 2f7c24f..30463fe 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponseElement.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ShowLocksResponseElement.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLocksResponseElement, ShowLocksResponseElement._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLocksResponseElement, ShowLocksResponseElement._Fields>, java.io.Serializable, Cloneable, Comparable<ShowLocksResponseElement> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ShowLocksResponseElement");
 
   private static final org.apache.thrift.protocol.TField LOCKID_FIELD_DESC = new org.apache.thrift.protocol.TField("lockid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -166,7 +170,7 @@ public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLoc
   private static final int __LASTHEARTBEAT_ISSET_ID = 2;
   private static final int __ACQUIREDAT_ISSET_ID = 3;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.TABLENAME,_Fields.PARTNAME,_Fields.TXNID,_Fields.ACQUIREDAT};
+  private static final _Fields optionals[] = {_Fields.TABLENAME,_Fields.PARTNAME,_Fields.TXNID,_Fields.ACQUIREDAT};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -822,180 +826,180 @@ public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLoc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lockid = true;
-    builder.append(present_lockid);
+    list.add(present_lockid);
     if (present_lockid)
-      builder.append(lockid);
+      list.add(lockid);
 
     boolean present_dbname = true && (isSetDbname());
-    builder.append(present_dbname);
+    list.add(present_dbname);
     if (present_dbname)
-      builder.append(dbname);
+      list.add(dbname);
 
     boolean present_tablename = true && (isSetTablename());
-    builder.append(present_tablename);
+    list.add(present_tablename);
     if (present_tablename)
-      builder.append(tablename);
+      list.add(tablename);
 
     boolean present_partname = true && (isSetPartname());
-    builder.append(present_partname);
+    list.add(present_partname);
     if (present_partname)
-      builder.append(partname);
+      list.add(partname);
 
     boolean present_state = true && (isSetState());
-    builder.append(present_state);
+    list.add(present_state);
     if (present_state)
-      builder.append(state.getValue());
+      list.add(state.getValue());
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type.getValue());
+      list.add(type.getValue());
 
     boolean present_txnid = true && (isSetTxnid());
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
     boolean present_lastheartbeat = true;
-    builder.append(present_lastheartbeat);
+    list.add(present_lastheartbeat);
     if (present_lastheartbeat)
-      builder.append(lastheartbeat);
+      list.add(lastheartbeat);
 
     boolean present_acquiredat = true && (isSetAcquiredat());
-    builder.append(present_acquiredat);
+    list.add(present_acquiredat);
     if (present_acquiredat)
-      builder.append(acquiredat);
+      list.add(acquiredat);
 
     boolean present_user = true && (isSetUser());
-    builder.append(present_user);
+    list.add(present_user);
     if (present_user)
-      builder.append(user);
+      list.add(user);
 
     boolean present_hostname = true && (isSetHostname());
-    builder.append(present_hostname);
+    list.add(present_hostname);
     if (present_hostname)
-      builder.append(hostname);
+      list.add(hostname);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ShowLocksResponseElement other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ShowLocksResponseElement typedOther = (ShowLocksResponseElement)other;
 
-    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(typedOther.isSetLockid());
+    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(other.isSetLockid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLockid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, typedOther.lockid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, other.lockid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(typedOther.isSetDbname());
+    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(other.isSetDbname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, typedOther.dbname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, other.dbname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(typedOther.isSetTablename());
+    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(other.isSetTablename());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTablename()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, typedOther.tablename);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, other.tablename);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartname()).compareTo(typedOther.isSetPartname());
+    lastComparison = Boolean.valueOf(isSetPartname()).compareTo(other.isSetPartname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partname, typedOther.partname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partname, other.partname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetState()).compareTo(typedOther.isSetState());
+    lastComparison = Boolean.valueOf(isSetState()).compareTo(other.isSetState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, typedOther.state);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, other.state);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastheartbeat()).compareTo(typedOther.isSetLastheartbeat());
+    lastComparison = Boolean.valueOf(isSetLastheartbeat()).compareTo(other.isSetLastheartbeat());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastheartbeat()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastheartbeat, typedOther.lastheartbeat);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastheartbeat, other.lastheartbeat);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAcquiredat()).compareTo(typedOther.isSetAcquiredat());
+    lastComparison = Boolean.valueOf(isSetAcquiredat()).compareTo(other.isSetAcquiredat());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAcquiredat()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.acquiredat, typedOther.acquiredat);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.acquiredat, other.acquiredat);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUser()).compareTo(typedOther.isSetUser());
+    lastComparison = Boolean.valueOf(isSetUser()).compareTo(other.isSetUser());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUser()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, typedOther.user);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, other.user);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(typedOther.isSetHostname());
+    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(other.isSetHostname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHostname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, typedOther.hostname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, other.hostname);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -1206,7 +1210,7 @@ public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLoc
             break;
           case 5: // STATE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.state = LockState.findByValue(iprot.readI32());
+              struct.state = org.apache.hadoop.hive.metastore.api.LockState.findByValue(iprot.readI32());
               struct.setStateIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1214,7 +1218,7 @@ public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLoc
             break;
           case 6: // TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.type = LockType.findByValue(iprot.readI32());
+              struct.type = org.apache.hadoop.hive.metastore.api.LockType.findByValue(iprot.readI32());
               struct.setTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1387,9 +1391,9 @@ public class ShowLocksResponseElement implements org.apache.thrift.TBase<ShowLoc
       struct.setLockidIsSet(true);
       struct.dbname = iprot.readString();
       struct.setDbnameIsSet(true);
-      struct.state = LockState.findByValue(iprot.readI32());
+      struct.state = org.apache.hadoop.hive.metastore.api.LockState.findByValue(iprot.readI32());
       struct.setStateIsSet(true);
-      struct.type = LockType.findByValue(iprot.readI32());
+      struct.type = org.apache.hadoop.hive.metastore.api.LockType.findByValue(iprot.readI32());
       struct.setTypeIsSet(true);
       struct.lastheartbeat = iprot.readI64();
       struct.setLastheartbeatIsSet(true);


[06/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsResp.java
index 19991f1..3f8dbb8 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TFetchResultsResp implements org.apache.thrift.TBase<TFetchResultsResp, TFetchResultsResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TFetchResultsResp implements org.apache.thrift.TBase<TFetchResultsResp, TFetchResultsResp._Fields>, java.io.Serializable, Cloneable, Comparable<TFetchResultsResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TFetchResultsResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -115,7 +119,7 @@ public class TFetchResultsResp implements org.apache.thrift.TBase<TFetchResultsR
   // isset id assignments
   private static final int __HASMOREROWS_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.HAS_MORE_ROWS,_Fields.RESULTS};
+  private static final _Fields optionals[] = {_Fields.HAS_MORE_ROWS,_Fields.RESULTS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -339,60 +343,60 @@ public class TFetchResultsResp implements org.apache.thrift.TBase<TFetchResultsR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_hasMoreRows = true && (isSetHasMoreRows());
-    builder.append(present_hasMoreRows);
+    list.add(present_hasMoreRows);
     if (present_hasMoreRows)
-      builder.append(hasMoreRows);
+      list.add(hasMoreRows);
 
     boolean present_results = true && (isSetResults());
-    builder.append(present_results);
+    list.add(present_results);
     if (present_results)
-      builder.append(results);
+      list.add(results);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TFetchResultsResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TFetchResultsResp typedOther = (TFetchResultsResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHasMoreRows()).compareTo(typedOther.isSetHasMoreRows());
+    lastComparison = Boolean.valueOf(isSetHasMoreRows()).compareTo(other.isSetHasMoreRows());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHasMoreRows()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasMoreRows, typedOther.hasMoreRows);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasMoreRows, other.hasMoreRows);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetResults()).compareTo(typedOther.isSetResults());
+    lastComparison = Boolean.valueOf(isSetResults()).compareTo(other.isSetResults());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetResults()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.results, typedOther.results);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.results, other.results);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsReq.java
index cfd157f..41c5b4b 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetCatalogsReq implements org.apache.thrift.TBase<TGetCatalogsReq, TGetCatalogsReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetCatalogsReq implements org.apache.thrift.TBase<TGetCatalogsReq, TGetCatalogsReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetCatalogsReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetCatalogsReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TGetCatalogsReq implements org.apache.thrift.TBase<TGetCatalogsReq,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetCatalogsReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetCatalogsReq typedOther = (TGetCatalogsReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsResp.java
index 1c5a354..cae7341 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetCatalogsResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetCatalogsResp implements org.apache.thrift.TBase<TGetCatalogsResp, TGetCatalogsResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetCatalogsResp implements org.apache.thrift.TBase<TGetCatalogsResp, TGetCatalogsResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetCatalogsResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetCatalogsResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetCatalogsResp implements org.apache.thrift.TBase<TGetCatalogsRes
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetCatalogsResp implements org.apache.thrift.TBase<TGetCatalogsRes
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetCatalogsResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetCatalogsResp typedOther = (TGetCatalogsResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsReq.java
index a2c793b..bbde470 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetColumnsReq implements org.apache.thrift.TBase<TGetColumnsReq, TGetColumnsReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetColumnsReq implements org.apache.thrift.TBase<TGetColumnsReq, TGetColumnsReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetColumnsReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetColumnsReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -123,7 +127,7 @@ public class TGetColumnsReq implements org.apache.thrift.TBase<TGetColumnsReq, T
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME,_Fields.TABLE_NAME,_Fields.COLUMN_NAME};
+  private static final _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME,_Fields.TABLE_NAME,_Fields.COLUMN_NAME};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -450,90 +454,90 @@ public class TGetColumnsReq implements org.apache.thrift.TBase<TGetColumnsReq, T
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_catalogName = true && (isSetCatalogName());
-    builder.append(present_catalogName);
+    list.add(present_catalogName);
     if (present_catalogName)
-      builder.append(catalogName);
+      list.add(catalogName);
 
     boolean present_schemaName = true && (isSetSchemaName());
-    builder.append(present_schemaName);
+    list.add(present_schemaName);
     if (present_schemaName)
-      builder.append(schemaName);
+      list.add(schemaName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_columnName = true && (isSetColumnName());
-    builder.append(present_columnName);
+    list.add(present_columnName);
     if (present_columnName)
-      builder.append(columnName);
+      list.add(columnName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetColumnsReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetColumnsReq typedOther = (TGetColumnsReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(typedOther.isSetCatalogName());
+    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(other.isSetCatalogName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCatalogName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, typedOther.catalogName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, other.catalogName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(typedOther.isSetSchemaName());
+    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(other.isSetSchemaName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSchemaName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, typedOther.schemaName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, other.schemaName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(typedOther.isSetColumnName());
+    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(other.isSetColumnName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColumnName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, typedOther.columnName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, other.columnName);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsResp.java
index d6cf1be..a180dab 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetColumnsResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetColumnsResp implements org.apache.thrift.TBase<TGetColumnsResp, TGetColumnsResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetColumnsResp implements org.apache.thrift.TBase<TGetColumnsResp, TGetColumnsResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetColumnsResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetColumnsResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetColumnsResp implements org.apache.thrift.TBase<TGetColumnsResp,
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetColumnsResp implements org.apache.thrift.TBase<TGetColumnsResp,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetColumnsResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetColumnsResp typedOther = (TGetColumnsResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenReq.java
index 6c6bb00..87fe609 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetDelegationTokenReq implements org.apache.thrift.TBase<TGetDelegationTokenReq, TGetDelegationTokenReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetDelegationTokenReq implements org.apache.thrift.TBase<TGetDelegationTokenReq, TGetDelegationTokenReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetDelegationTokenReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetDelegationTokenReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -341,60 +345,60 @@ public class TGetDelegationTokenReq implements org.apache.thrift.TBase<TGetDeleg
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_owner = true && (isSetOwner());
-    builder.append(present_owner);
+    list.add(present_owner);
     if (present_owner)
-      builder.append(owner);
+      list.add(owner);
 
     boolean present_renewer = true && (isSetRenewer());
-    builder.append(present_renewer);
+    list.add(present_renewer);
     if (present_renewer)
-      builder.append(renewer);
+      list.add(renewer);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetDelegationTokenReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetDelegationTokenReq typedOther = (TGetDelegationTokenReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwner()).compareTo(typedOther.isSetOwner());
+    lastComparison = Boolean.valueOf(isSetOwner()).compareTo(other.isSetOwner());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwner()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.owner, typedOther.owner);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.owner, other.owner);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRenewer()).compareTo(typedOther.isSetRenewer());
+    lastComparison = Boolean.valueOf(isSetRenewer()).compareTo(other.isSetRenewer());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRenewer()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.renewer, typedOther.renewer);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.renewer, other.renewer);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenResp.java
index d14c5e0..93894d3 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetDelegationTokenResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetDelegationTokenResp implements org.apache.thrift.TBase<TGetDelegationTokenResp, TGetDelegationTokenResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetDelegationTokenResp implements org.apache.thrift.TBase<TGetDelegationTokenResp, TGetDelegationTokenResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetDelegationTokenResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetDelegationTokenResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetDelegationTokenResp implements org.apache.thrift.TBase<TGetDele
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.DELEGATION_TOKEN};
+  private static final _Fields optionals[] = {_Fields.DELEGATION_TOKEN};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetDelegationTokenResp implements org.apache.thrift.TBase<TGetDele
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_delegationToken = true && (isSetDelegationToken());
-    builder.append(present_delegationToken);
+    list.add(present_delegationToken);
     if (present_delegationToken)
-      builder.append(delegationToken);
+      list.add(delegationToken);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetDelegationTokenResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetDelegationTokenResp typedOther = (TGetDelegationTokenResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(typedOther.isSetDelegationToken());
+    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(other.isSetDelegationToken());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDelegationToken()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, typedOther.delegationToken);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, other.delegationToken);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsReq.java
index ff45ee0..034e4b0 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetFunctionsReq implements org.apache.thrift.TBase<TGetFunctionsReq, TGetFunctionsReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetFunctionsReq implements org.apache.thrift.TBase<TGetFunctionsReq, TGetFunctionsReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetFunctionsReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetFunctionsReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -118,7 +122,7 @@ public class TGetFunctionsReq implements org.apache.thrift.TBase<TGetFunctionsRe
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME};
+  private static final _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -396,75 +400,75 @@ public class TGetFunctionsReq implements org.apache.thrift.TBase<TGetFunctionsRe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_catalogName = true && (isSetCatalogName());
-    builder.append(present_catalogName);
+    list.add(present_catalogName);
     if (present_catalogName)
-      builder.append(catalogName);
+      list.add(catalogName);
 
     boolean present_schemaName = true && (isSetSchemaName());
-    builder.append(present_schemaName);
+    list.add(present_schemaName);
     if (present_schemaName)
-      builder.append(schemaName);
+      list.add(schemaName);
 
     boolean present_functionName = true && (isSetFunctionName());
-    builder.append(present_functionName);
+    list.add(present_functionName);
     if (present_functionName)
-      builder.append(functionName);
+      list.add(functionName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetFunctionsReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetFunctionsReq typedOther = (TGetFunctionsReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(typedOther.isSetCatalogName());
+    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(other.isSetCatalogName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCatalogName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, typedOther.catalogName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, other.catalogName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(typedOther.isSetSchemaName());
+    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(other.isSetSchemaName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSchemaName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, typedOther.schemaName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, other.schemaName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetFunctionName()).compareTo(typedOther.isSetFunctionName());
+    lastComparison = Boolean.valueOf(isSetFunctionName()).compareTo(other.isSetFunctionName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFunctionName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionName, typedOther.functionName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionName, other.functionName);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsResp.java
index 3adafda..1c2ba7a 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetFunctionsResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetFunctionsResp implements org.apache.thrift.TBase<TGetFunctionsResp, TGetFunctionsResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetFunctionsResp implements org.apache.thrift.TBase<TGetFunctionsResp, TGetFunctionsResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetFunctionsResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetFunctionsResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetFunctionsResp implements org.apache.thrift.TBase<TGetFunctionsR
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetFunctionsResp implements org.apache.thrift.TBase<TGetFunctionsR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetFunctionsResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetFunctionsResp typedOther = (TGetFunctionsResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoReq.java
index 0139bf0..6110e92 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetInfoReq implements org.apache.thrift.TBase<TGetInfoReq, TGetInfoReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetInfoReq implements org.apache.thrift.TBase<TGetInfoReq, TGetInfoReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetInfoReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetInfoReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -295,45 +299,45 @@ public class TGetInfoReq implements org.apache.thrift.TBase<TGetInfoReq, TGetInf
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_infoType = true && (isSetInfoType());
-    builder.append(present_infoType);
+    list.add(present_infoType);
     if (present_infoType)
-      builder.append(infoType.getValue());
+      list.add(infoType.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetInfoReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetInfoReq typedOther = (TGetInfoReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetInfoType()).compareTo(typedOther.isSetInfoType());
+    lastComparison = Boolean.valueOf(isSetInfoType()).compareTo(other.isSetInfoType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetInfoType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoType, typedOther.infoType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoType, other.infoType);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -438,7 +442,7 @@ public class TGetInfoReq implements org.apache.thrift.TBase<TGetInfoReq, TGetInf
             break;
           case 2: // INFO_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.infoType = TGetInfoType.findByValue(iprot.readI32());
+              struct.infoType = org.apache.hive.service.cli.thrift.TGetInfoType.findByValue(iprot.readI32());
               struct.setInfoTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -494,7 +498,7 @@ public class TGetInfoReq implements org.apache.thrift.TBase<TGetInfoReq, TGetInf
       struct.sessionHandle = new TSessionHandle();
       struct.sessionHandle.read(iprot);
       struct.setSessionHandleIsSet(true);
-      struct.infoType = TGetInfoType.findByValue(iprot.readI32());
+      struct.infoType = org.apache.hive.service.cli.thrift.TGetInfoType.findByValue(iprot.readI32());
       struct.setInfoTypeIsSet(true);
     }
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoResp.java
index 2faaa92..61d04c0 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetInfoResp implements org.apache.thrift.TBase<TGetInfoResp, TGetInfoResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetInfoResp implements org.apache.thrift.TBase<TGetInfoResp, TGetInfoResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetInfoResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetInfoResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -283,45 +287,45 @@ public class TGetInfoResp implements org.apache.thrift.TBase<TGetInfoResp, TGetI
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_infoValue = true && (isSetInfoValue());
-    builder.append(present_infoValue);
+    list.add(present_infoValue);
     if (present_infoValue)
-      builder.append(infoValue);
+      list.add(infoValue);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetInfoResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetInfoResp typedOther = (TGetInfoResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetInfoValue()).compareTo(typedOther.isSetInfoValue());
+    lastComparison = Boolean.valueOf(isSetInfoValue()).compareTo(other.isSetInfoValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetInfoValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoValue, typedOther.infoValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoValue, other.infoValue);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoType.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoType.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoType.java
index d9dd624..f4dc73d 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoType.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoValue.java
index 4fe59b1..af1224d 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetInfoValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TGetInfoValue extends org.apache.thrift.TUnion<TGetInfoValue, TGetInfoValue._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetInfoValue");
   private static final org.apache.thrift.protocol.TField STRING_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("stringValue", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -285,6 +288,7 @@ public class TGetInfoValue extends org.apache.thrift.TUnion<TGetInfoValue, TGetI
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -558,19 +562,19 @@ public class TGetInfoValue extends org.apache.thrift.TUnion<TGetInfoValue, TGetI
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusReq.java
index b88591e..0dd2b2e 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetOperationStatusReq implements org.apache.thrift.TBase<TGetOperationStatusReq, TGetOperationStatusReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetOperationStatusReq implements org.apache.thrift.TBase<TGetOperationStatusReq, TGetOperationStatusReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetOperationStatusReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetOperationStatusReq");
 
   private static final org.apache.thrift.protocol.TField OPERATION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("operationHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TGetOperationStatusReq implements org.apache.thrift.TBase<TGetOpera
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetOperationStatusReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetOperationStatusReq typedOther = (TGetOperationStatusReq)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusResp.java
index 94ba6bb..0c7e61f 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetOperationStatusResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOperationStatusResp, TGetOperationStatusResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOperationStatusResp, TGetOperationStatusResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetOperationStatusResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetOperationStatusResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -129,7 +133,7 @@ public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOper
   // isset id assignments
   private static final int __ERRORCODE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.OPERATION_STATE,_Fields.SQL_STATE,_Fields.ERROR_CODE,_Fields.ERROR_MESSAGE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_STATE,_Fields.SQL_STATE,_Fields.ERROR_CODE,_Fields.ERROR_MESSAGE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -463,90 +467,90 @@ public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOper
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationState = true && (isSetOperationState());
-    builder.append(present_operationState);
+    list.add(present_operationState);
     if (present_operationState)
-      builder.append(operationState.getValue());
+      list.add(operationState.getValue());
 
     boolean present_sqlState = true && (isSetSqlState());
-    builder.append(present_sqlState);
+    list.add(present_sqlState);
     if (present_sqlState)
-      builder.append(sqlState);
+      list.add(sqlState);
 
     boolean present_errorCode = true && (isSetErrorCode());
-    builder.append(present_errorCode);
+    list.add(present_errorCode);
     if (present_errorCode)
-      builder.append(errorCode);
+      list.add(errorCode);
 
     boolean present_errorMessage = true && (isSetErrorMessage());
-    builder.append(present_errorMessage);
+    list.add(present_errorMessage);
     if (present_errorMessage)
-      builder.append(errorMessage);
+      list.add(errorMessage);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetOperationStatusResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetOperationStatusResp typedOther = (TGetOperationStatusResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationState()).compareTo(typedOther.isSetOperationState());
+    lastComparison = Boolean.valueOf(isSetOperationState()).compareTo(other.isSetOperationState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationState, typedOther.operationState);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationState, other.operationState);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSqlState()).compareTo(typedOther.isSetSqlState());
+    lastComparison = Boolean.valueOf(isSetSqlState()).compareTo(other.isSetSqlState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSqlState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sqlState, typedOther.sqlState);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sqlState, other.sqlState);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(typedOther.isSetErrorCode());
+    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(other.isSetErrorCode());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetErrorCode()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, typedOther.errorCode);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, other.errorCode);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetErrorMessage()).compareTo(typedOther.isSetErrorMessage());
+    lastComparison = Boolean.valueOf(isSetErrorMessage()).compareTo(other.isSetErrorMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetErrorMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorMessage, typedOther.errorMessage);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorMessage, other.errorMessage);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -677,7 +681,7 @@ public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOper
             break;
           case 2: // OPERATION_STATE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.operationState = TOperationState.findByValue(iprot.readI32());
+              struct.operationState = org.apache.hive.service.cli.thrift.TOperationState.findByValue(iprot.readI32());
               struct.setOperationStateIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -805,7 +809,7 @@ public class TGetOperationStatusResp implements org.apache.thrift.TBase<TGetOper
       struct.setStatusIsSet(true);
       BitSet incoming = iprot.readBitSet(4);
       if (incoming.get(0)) {
-        struct.operationState = TOperationState.findByValue(iprot.readI32());
+        struct.operationState = org.apache.hive.service.cli.thrift.TOperationState.findByValue(iprot.readI32());
         struct.setOperationStateIsSet(true);
       }
       if (incoming.get(1)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataReq.java
index 3bf363c..77ee850 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetResultSetMetadataReq implements org.apache.thrift.TBase<TGetResultSetMetadataReq, TGetResultSetMetadataReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetResultSetMetadataReq implements org.apache.thrift.TBase<TGetResultSetMetadataReq, TGetResultSetMetadataReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetResultSetMetadataReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetResultSetMetadataReq");
 
   private static final org.apache.thrift.protocol.TField OPERATION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("operationHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TGetResultSetMetadataReq implements org.apache.thrift.TBase<TGetRes
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetResultSetMetadataReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetResultSetMetadataReq typedOther = (TGetResultSetMetadataReq)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataResp.java
index a9bef9f..9dbed7a 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetResultSetMetadataResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetResultSetMetadataResp implements org.apache.thrift.TBase<TGetResultSetMetadataResp, TGetResultSetMetadataResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetResultSetMetadataResp implements org.apache.thrift.TBase<TGetResultSetMetadataResp, TGetResultSetMetadataResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetResultSetMetadataResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetResultSetMetadataResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetResultSetMetadataResp implements org.apache.thrift.TBase<TGetRe
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.SCHEMA};
+  private static final _Fields optionals[] = {_Fields.SCHEMA};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetResultSetMetadataResp implements org.apache.thrift.TBase<TGetRe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_schema = true && (isSetSchema());
-    builder.append(present_schema);
+    list.add(present_schema);
     if (present_schema)
-      builder.append(schema);
+      list.add(schema);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetResultSetMetadataResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetResultSetMetadataResp typedOther = (TGetResultSetMetadataResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSchema()).compareTo(typedOther.isSetSchema());
+    lastComparison = Boolean.valueOf(isSetSchema()).compareTo(other.isSetSchema());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSchema()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schema, typedOther.schema);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schema, other.schema);
       if (lastComparison != 0) {
         return lastComparison;
       }


[26/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-cpp/queryplan_types.cpp
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-cpp/queryplan_types.cpp b/ql/src/gen/thrift/gen-cpp/queryplan_types.cpp
index 19d4806..a1fb60b 100644
--- a/ql/src/gen/thrift/gen-cpp/queryplan_types.cpp
+++ b/ql/src/gen/thrift/gen-cpp/queryplan_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "queryplan_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 namespace Apache { namespace Hadoop { namespace Hive {
 
@@ -55,7 +58,8 @@ int _kOperatorTypeValues[] = {
   OperatorType::EVENT,
   OperatorType::ORCFILEMERGE,
   OperatorType::RCFILEMERGE,
-  OperatorType::MERGEJOIN
+  OperatorType::MERGEJOIN,
+  OperatorType::SPARKPRUNINGSINK
 };
 const char* _kOperatorTypeNames[] = {
   "JOIN",
@@ -82,9 +86,10 @@ const char* _kOperatorTypeNames[] = {
   "EVENT",
   "ORCFILEMERGE",
   "RCFILEMERGE",
-  "MERGEJOIN"
+  "MERGEJOIN",
+  "SPARKPRUNINGSINK"
 };
-const std::map<int, const char*> _OperatorType_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(25, _kOperatorTypeValues, _kOperatorTypeNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
+const std::map<int, const char*> _OperatorType_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(26, _kOperatorTypeValues, _kOperatorTypeNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
 int _kTaskTypeValues[] = {
   TaskType::MAP,
@@ -128,6 +133,23 @@ const char* _kStageTypeNames[] = {
 };
 const std::map<int, const char*> _StageType_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(12, _kStageTypeValues, _kStageTypeNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
+
+Adjacency::~Adjacency() throw() {
+}
+
+
+void Adjacency::__set_node(const std::string& val) {
+  this->node = val;
+}
+
+void Adjacency::__set_children(const std::vector<std::string> & val) {
+  this->children = val;
+}
+
+void Adjacency::__set_adjacencyType(const AdjacencyType::type val) {
+  this->adjacencyType = val;
+}
+
 const char* Adjacency::ascii_fingerprint = "BC4F8C394677A1003AA9F56ED26D8204";
 const uint8_t Adjacency::binary_fingerprint[16] = {0xBC,0x4F,0x8C,0x39,0x46,0x77,0xA1,0x00,0x3A,0xA9,0xF5,0x6E,0xD2,0x6D,0x82,0x04};
 
@@ -203,6 +225,7 @@ uint32_t Adjacency::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Adjacency::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Adjacency");
 
   xfer += oprot->writeFieldBegin("node", ::apache::thrift::protocol::T_STRING, 1);
@@ -227,6 +250,7 @@ uint32_t Adjacency::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -238,6 +262,46 @@ void swap(Adjacency &a, Adjacency &b) {
   swap(a.__isset, b.__isset);
 }
 
+Adjacency::Adjacency(const Adjacency& other7) {
+  node = other7.node;
+  children = other7.children;
+  adjacencyType = other7.adjacencyType;
+  __isset = other7.__isset;
+}
+Adjacency& Adjacency::operator=(const Adjacency& other8) {
+  node = other8.node;
+  children = other8.children;
+  adjacencyType = other8.adjacencyType;
+  __isset = other8.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Adjacency& obj) {
+  using apache::thrift::to_string;
+  out << "Adjacency(";
+  out << "node=" << to_string(obj.node);
+  out << ", " << "children=" << to_string(obj.children);
+  out << ", " << "adjacencyType=" << to_string(obj.adjacencyType);
+  out << ")";
+  return out;
+}
+
+
+Graph::~Graph() throw() {
+}
+
+
+void Graph::__set_nodeType(const NodeType::type val) {
+  this->nodeType = val;
+}
+
+void Graph::__set_roots(const std::vector<std::string> & val) {
+  this->roots = val;
+}
+
+void Graph::__set_adjacencyList(const std::vector<Adjacency> & val) {
+  this->adjacencyList = val;
+}
+
 const char* Graph::ascii_fingerprint = "1F7FB604B3EF8F7AFB5DEAD15F2FC0B5";
 const uint8_t Graph::binary_fingerprint[16] = {0x1F,0x7F,0xB6,0x04,0xB3,0xEF,0x8F,0x7A,0xFB,0x5D,0xEA,0xD1,0x5F,0x2F,0xC0,0xB5};
 
@@ -263,9 +327,9 @@ uint32_t Graph::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast7;
-          xfer += iprot->readI32(ecast7);
-          this->nodeType = (NodeType::type)ecast7;
+          int32_t ecast9;
+          xfer += iprot->readI32(ecast9);
+          this->nodeType = (NodeType::type)ecast9;
           this->__isset.nodeType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -275,14 +339,14 @@ uint32_t Graph::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->roots.clear();
-            uint32_t _size8;
-            ::apache::thrift::protocol::TType _etype11;
-            xfer += iprot->readListBegin(_etype11, _size8);
-            this->roots.resize(_size8);
-            uint32_t _i12;
-            for (_i12 = 0; _i12 < _size8; ++_i12)
+            uint32_t _size10;
+            ::apache::thrift::protocol::TType _etype13;
+            xfer += iprot->readListBegin(_etype13, _size10);
+            this->roots.resize(_size10);
+            uint32_t _i14;
+            for (_i14 = 0; _i14 < _size10; ++_i14)
             {
-              xfer += iprot->readString(this->roots[_i12]);
+              xfer += iprot->readString(this->roots[_i14]);
             }
             xfer += iprot->readListEnd();
           }
@@ -295,14 +359,14 @@ uint32_t Graph::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->adjacencyList.clear();
-            uint32_t _size13;
-            ::apache::thrift::protocol::TType _etype16;
-            xfer += iprot->readListBegin(_etype16, _size13);
-            this->adjacencyList.resize(_size13);
-            uint32_t _i17;
-            for (_i17 = 0; _i17 < _size13; ++_i17)
+            uint32_t _size15;
+            ::apache::thrift::protocol::TType _etype18;
+            xfer += iprot->readListBegin(_etype18, _size15);
+            this->adjacencyList.resize(_size15);
+            uint32_t _i19;
+            for (_i19 = 0; _i19 < _size15; ++_i19)
             {
-              xfer += this->adjacencyList[_i17].read(iprot);
+              xfer += this->adjacencyList[_i19].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -325,6 +389,7 @@ uint32_t Graph::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Graph::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Graph");
 
   xfer += oprot->writeFieldBegin("nodeType", ::apache::thrift::protocol::T_I32, 1);
@@ -334,10 +399,10 @@ uint32_t Graph::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("roots", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->roots.size()));
-    std::vector<std::string> ::const_iterator _iter18;
-    for (_iter18 = this->roots.begin(); _iter18 != this->roots.end(); ++_iter18)
+    std::vector<std::string> ::const_iterator _iter20;
+    for (_iter20 = this->roots.begin(); _iter20 != this->roots.end(); ++_iter20)
     {
-      xfer += oprot->writeString((*_iter18));
+      xfer += oprot->writeString((*_iter20));
     }
     xfer += oprot->writeListEnd();
   }
@@ -346,10 +411,10 @@ uint32_t Graph::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("adjacencyList", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->adjacencyList.size()));
-    std::vector<Adjacency> ::const_iterator _iter19;
-    for (_iter19 = this->adjacencyList.begin(); _iter19 != this->adjacencyList.end(); ++_iter19)
+    std::vector<Adjacency> ::const_iterator _iter21;
+    for (_iter21 = this->adjacencyList.begin(); _iter21 != this->adjacencyList.end(); ++_iter21)
     {
-      xfer += (*_iter19).write(oprot);
+      xfer += (*_iter21).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -357,6 +422,7 @@ uint32_t Graph::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -368,6 +434,58 @@ void swap(Graph &a, Graph &b) {
   swap(a.__isset, b.__isset);
 }
 
+Graph::Graph(const Graph& other22) {
+  nodeType = other22.nodeType;
+  roots = other22.roots;
+  adjacencyList = other22.adjacencyList;
+  __isset = other22.__isset;
+}
+Graph& Graph::operator=(const Graph& other23) {
+  nodeType = other23.nodeType;
+  roots = other23.roots;
+  adjacencyList = other23.adjacencyList;
+  __isset = other23.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Graph& obj) {
+  using apache::thrift::to_string;
+  out << "Graph(";
+  out << "nodeType=" << to_string(obj.nodeType);
+  out << ", " << "roots=" << to_string(obj.roots);
+  out << ", " << "adjacencyList=" << to_string(obj.adjacencyList);
+  out << ")";
+  return out;
+}
+
+
+Operator::~Operator() throw() {
+}
+
+
+void Operator::__set_operatorId(const std::string& val) {
+  this->operatorId = val;
+}
+
+void Operator::__set_operatorType(const OperatorType::type val) {
+  this->operatorType = val;
+}
+
+void Operator::__set_operatorAttributes(const std::map<std::string, std::string> & val) {
+  this->operatorAttributes = val;
+}
+
+void Operator::__set_operatorCounters(const std::map<std::string, int64_t> & val) {
+  this->operatorCounters = val;
+}
+
+void Operator::__set_done(const bool val) {
+  this->done = val;
+}
+
+void Operator::__set_started(const bool val) {
+  this->started = val;
+}
+
 const char* Operator::ascii_fingerprint = "30917C758A752485AF223B697479DE6C";
 const uint8_t Operator::binary_fingerprint[16] = {0x30,0x91,0x7C,0x75,0x8A,0x75,0x24,0x85,0xAF,0x22,0x3B,0x69,0x74,0x79,0xDE,0x6C};
 
@@ -401,9 +519,9 @@ uint32_t Operator::read(::apache::thrift::protocol::TProtocol* iprot) {
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast20;
-          xfer += iprot->readI32(ecast20);
-          this->operatorType = (OperatorType::type)ecast20;
+          int32_t ecast24;
+          xfer += iprot->readI32(ecast24);
+          this->operatorType = (OperatorType::type)ecast24;
           this->__isset.operatorType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -413,17 +531,17 @@ uint32_t Operator::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->operatorAttributes.clear();
-            uint32_t _size21;
-            ::apache::thrift::protocol::TType _ktype22;
-            ::apache::thrift::protocol::TType _vtype23;
-            xfer += iprot->readMapBegin(_ktype22, _vtype23, _size21);
-            uint32_t _i25;
-            for (_i25 = 0; _i25 < _size21; ++_i25)
+            uint32_t _size25;
+            ::apache::thrift::protocol::TType _ktype26;
+            ::apache::thrift::protocol::TType _vtype27;
+            xfer += iprot->readMapBegin(_ktype26, _vtype27, _size25);
+            uint32_t _i29;
+            for (_i29 = 0; _i29 < _size25; ++_i29)
             {
-              std::string _key26;
-              xfer += iprot->readString(_key26);
-              std::string& _val27 = this->operatorAttributes[_key26];
-              xfer += iprot->readString(_val27);
+              std::string _key30;
+              xfer += iprot->readString(_key30);
+              std::string& _val31 = this->operatorAttributes[_key30];
+              xfer += iprot->readString(_val31);
             }
             xfer += iprot->readMapEnd();
           }
@@ -436,17 +554,17 @@ uint32_t Operator::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->operatorCounters.clear();
-            uint32_t _size28;
-            ::apache::thrift::protocol::TType _ktype29;
-            ::apache::thrift::protocol::TType _vtype30;
-            xfer += iprot->readMapBegin(_ktype29, _vtype30, _size28);
-            uint32_t _i32;
-            for (_i32 = 0; _i32 < _size28; ++_i32)
+            uint32_t _size32;
+            ::apache::thrift::protocol::TType _ktype33;
+            ::apache::thrift::protocol::TType _vtype34;
+            xfer += iprot->readMapBegin(_ktype33, _vtype34, _size32);
+            uint32_t _i36;
+            for (_i36 = 0; _i36 < _size32; ++_i36)
             {
-              std::string _key33;
-              xfer += iprot->readString(_key33);
-              int64_t& _val34 = this->operatorCounters[_key33];
-              xfer += iprot->readI64(_val34);
+              std::string _key37;
+              xfer += iprot->readString(_key37);
+              int64_t& _val38 = this->operatorCounters[_key37];
+              xfer += iprot->readI64(_val38);
             }
             xfer += iprot->readMapEnd();
           }
@@ -485,6 +603,7 @@ uint32_t Operator::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Operator::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Operator");
 
   xfer += oprot->writeFieldBegin("operatorId", ::apache::thrift::protocol::T_STRING, 1);
@@ -498,11 +617,11 @@ uint32_t Operator::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("operatorAttributes", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->operatorAttributes.size()));
-    std::map<std::string, std::string> ::const_iterator _iter35;
-    for (_iter35 = this->operatorAttributes.begin(); _iter35 != this->operatorAttributes.end(); ++_iter35)
+    std::map<std::string, std::string> ::const_iterator _iter39;
+    for (_iter39 = this->operatorAttributes.begin(); _iter39 != this->operatorAttributes.end(); ++_iter39)
     {
-      xfer += oprot->writeString(_iter35->first);
-      xfer += oprot->writeString(_iter35->second);
+      xfer += oprot->writeString(_iter39->first);
+      xfer += oprot->writeString(_iter39->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -511,11 +630,11 @@ uint32_t Operator::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("operatorCounters", ::apache::thrift::protocol::T_MAP, 4);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->operatorCounters.size()));
-    std::map<std::string, int64_t> ::const_iterator _iter36;
-    for (_iter36 = this->operatorCounters.begin(); _iter36 != this->operatorCounters.end(); ++_iter36)
+    std::map<std::string, int64_t> ::const_iterator _iter40;
+    for (_iter40 = this->operatorCounters.begin(); _iter40 != this->operatorCounters.end(); ++_iter40)
     {
-      xfer += oprot->writeString(_iter36->first);
-      xfer += oprot->writeI64(_iter36->second);
+      xfer += oprot->writeString(_iter40->first);
+      xfer += oprot->writeI64(_iter40->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -531,6 +650,7 @@ uint32_t Operator::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -545,6 +665,77 @@ void swap(Operator &a, Operator &b) {
   swap(a.__isset, b.__isset);
 }
 
+Operator::Operator(const Operator& other41) {
+  operatorId = other41.operatorId;
+  operatorType = other41.operatorType;
+  operatorAttributes = other41.operatorAttributes;
+  operatorCounters = other41.operatorCounters;
+  done = other41.done;
+  started = other41.started;
+  __isset = other41.__isset;
+}
+Operator& Operator::operator=(const Operator& other42) {
+  operatorId = other42.operatorId;
+  operatorType = other42.operatorType;
+  operatorAttributes = other42.operatorAttributes;
+  operatorCounters = other42.operatorCounters;
+  done = other42.done;
+  started = other42.started;
+  __isset = other42.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Operator& obj) {
+  using apache::thrift::to_string;
+  out << "Operator(";
+  out << "operatorId=" << to_string(obj.operatorId);
+  out << ", " << "operatorType=" << to_string(obj.operatorType);
+  out << ", " << "operatorAttributes=" << to_string(obj.operatorAttributes);
+  out << ", " << "operatorCounters=" << to_string(obj.operatorCounters);
+  out << ", " << "done=" << to_string(obj.done);
+  out << ", " << "started=" << to_string(obj.started);
+  out << ")";
+  return out;
+}
+
+
+Task::~Task() throw() {
+}
+
+
+void Task::__set_taskId(const std::string& val) {
+  this->taskId = val;
+}
+
+void Task::__set_taskType(const TaskType::type val) {
+  this->taskType = val;
+}
+
+void Task::__set_taskAttributes(const std::map<std::string, std::string> & val) {
+  this->taskAttributes = val;
+}
+
+void Task::__set_taskCounters(const std::map<std::string, int64_t> & val) {
+  this->taskCounters = val;
+}
+
+void Task::__set_operatorGraph(const Graph& val) {
+  this->operatorGraph = val;
+__isset.operatorGraph = true;
+}
+
+void Task::__set_operatorList(const std::vector<Operator> & val) {
+  this->operatorList = val;
+__isset.operatorList = true;
+}
+
+void Task::__set_done(const bool val) {
+  this->done = val;
+}
+
+void Task::__set_started(const bool val) {
+  this->started = val;
+}
+
 const char* Task::ascii_fingerprint = "AC741A136EFA51843AFC3A12F6A793D1";
 const uint8_t Task::binary_fingerprint[16] = {0xAC,0x74,0x1A,0x13,0x6E,0xFA,0x51,0x84,0x3A,0xFC,0x3A,0x12,0xF6,0xA7,0x93,0xD1};
 
@@ -578,9 +769,9 @@ uint32_t Task::read(::apache::thrift::protocol::TProtocol* iprot) {
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast37;
-          xfer += iprot->readI32(ecast37);
-          this->taskType = (TaskType::type)ecast37;
+          int32_t ecast43;
+          xfer += iprot->readI32(ecast43);
+          this->taskType = (TaskType::type)ecast43;
           this->__isset.taskType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -590,17 +781,17 @@ uint32_t Task::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->taskAttributes.clear();
-            uint32_t _size38;
-            ::apache::thrift::protocol::TType _ktype39;
-            ::apache::thrift::protocol::TType _vtype40;
-            xfer += iprot->readMapBegin(_ktype39, _vtype40, _size38);
-            uint32_t _i42;
-            for (_i42 = 0; _i42 < _size38; ++_i42)
+            uint32_t _size44;
+            ::apache::thrift::protocol::TType _ktype45;
+            ::apache::thrift::protocol::TType _vtype46;
+            xfer += iprot->readMapBegin(_ktype45, _vtype46, _size44);
+            uint32_t _i48;
+            for (_i48 = 0; _i48 < _size44; ++_i48)
             {
-              std::string _key43;
-              xfer += iprot->readString(_key43);
-              std::string& _val44 = this->taskAttributes[_key43];
-              xfer += iprot->readString(_val44);
+              std::string _key49;
+              xfer += iprot->readString(_key49);
+              std::string& _val50 = this->taskAttributes[_key49];
+              xfer += iprot->readString(_val50);
             }
             xfer += iprot->readMapEnd();
           }
@@ -613,17 +804,17 @@ uint32_t Task::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->taskCounters.clear();
-            uint32_t _size45;
-            ::apache::thrift::protocol::TType _ktype46;
-            ::apache::thrift::protocol::TType _vtype47;
-            xfer += iprot->readMapBegin(_ktype46, _vtype47, _size45);
-            uint32_t _i49;
-            for (_i49 = 0; _i49 < _size45; ++_i49)
+            uint32_t _size51;
+            ::apache::thrift::protocol::TType _ktype52;
+            ::apache::thrift::protocol::TType _vtype53;
+            xfer += iprot->readMapBegin(_ktype52, _vtype53, _size51);
+            uint32_t _i55;
+            for (_i55 = 0; _i55 < _size51; ++_i55)
             {
-              std::string _key50;
-              xfer += iprot->readString(_key50);
-              int64_t& _val51 = this->taskCounters[_key50];
-              xfer += iprot->readI64(_val51);
+              std::string _key56;
+              xfer += iprot->readString(_key56);
+              int64_t& _val57 = this->taskCounters[_key56];
+              xfer += iprot->readI64(_val57);
             }
             xfer += iprot->readMapEnd();
           }
@@ -644,14 +835,14 @@ uint32_t Task::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->operatorList.clear();
-            uint32_t _size52;
-            ::apache::thrift::protocol::TType _etype55;
-            xfer += iprot->readListBegin(_etype55, _size52);
-            this->operatorList.resize(_size52);
-            uint32_t _i56;
-            for (_i56 = 0; _i56 < _size52; ++_i56)
+            uint32_t _size58;
+            ::apache::thrift::protocol::TType _etype61;
+            xfer += iprot->readListBegin(_etype61, _size58);
+            this->operatorList.resize(_size58);
+            uint32_t _i62;
+            for (_i62 = 0; _i62 < _size58; ++_i62)
             {
-              xfer += this->operatorList[_i56].read(iprot);
+              xfer += this->operatorList[_i62].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -690,6 +881,7 @@ uint32_t Task::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Task::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Task");
 
   xfer += oprot->writeFieldBegin("taskId", ::apache::thrift::protocol::T_STRING, 1);
@@ -703,11 +895,11 @@ uint32_t Task::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("taskAttributes", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->taskAttributes.size()));
-    std::map<std::string, std::string> ::const_iterator _iter57;
-    for (_iter57 = this->taskAttributes.begin(); _iter57 != this->taskAttributes.end(); ++_iter57)
+    std::map<std::string, std::string> ::const_iterator _iter63;
+    for (_iter63 = this->taskAttributes.begin(); _iter63 != this->taskAttributes.end(); ++_iter63)
     {
-      xfer += oprot->writeString(_iter57->first);
-      xfer += oprot->writeString(_iter57->second);
+      xfer += oprot->writeString(_iter63->first);
+      xfer += oprot->writeString(_iter63->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -716,11 +908,11 @@ uint32_t Task::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("taskCounters", ::apache::thrift::protocol::T_MAP, 4);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->taskCounters.size()));
-    std::map<std::string, int64_t> ::const_iterator _iter58;
-    for (_iter58 = this->taskCounters.begin(); _iter58 != this->taskCounters.end(); ++_iter58)
+    std::map<std::string, int64_t> ::const_iterator _iter64;
+    for (_iter64 = this->taskCounters.begin(); _iter64 != this->taskCounters.end(); ++_iter64)
     {
-      xfer += oprot->writeString(_iter58->first);
-      xfer += oprot->writeI64(_iter58->second);
+      xfer += oprot->writeString(_iter64->first);
+      xfer += oprot->writeI64(_iter64->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -735,10 +927,10 @@ uint32_t Task::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("operatorList", ::apache::thrift::protocol::T_LIST, 6);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->operatorList.size()));
-      std::vector<Operator> ::const_iterator _iter59;
-      for (_iter59 = this->operatorList.begin(); _iter59 != this->operatorList.end(); ++_iter59)
+      std::vector<Operator> ::const_iterator _iter65;
+      for (_iter65 = this->operatorList.begin(); _iter65 != this->operatorList.end(); ++_iter65)
       {
-        xfer += (*_iter59).write(oprot);
+        xfer += (*_iter65).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -754,6 +946,7 @@ uint32_t Task::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -770,6 +963,77 @@ void swap(Task &a, Task &b) {
   swap(a.__isset, b.__isset);
 }
 
+Task::Task(const Task& other66) {
+  taskId = other66.taskId;
+  taskType = other66.taskType;
+  taskAttributes = other66.taskAttributes;
+  taskCounters = other66.taskCounters;
+  operatorGraph = other66.operatorGraph;
+  operatorList = other66.operatorList;
+  done = other66.done;
+  started = other66.started;
+  __isset = other66.__isset;
+}
+Task& Task::operator=(const Task& other67) {
+  taskId = other67.taskId;
+  taskType = other67.taskType;
+  taskAttributes = other67.taskAttributes;
+  taskCounters = other67.taskCounters;
+  operatorGraph = other67.operatorGraph;
+  operatorList = other67.operatorList;
+  done = other67.done;
+  started = other67.started;
+  __isset = other67.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Task& obj) {
+  using apache::thrift::to_string;
+  out << "Task(";
+  out << "taskId=" << to_string(obj.taskId);
+  out << ", " << "taskType=" << to_string(obj.taskType);
+  out << ", " << "taskAttributes=" << to_string(obj.taskAttributes);
+  out << ", " << "taskCounters=" << to_string(obj.taskCounters);
+  out << ", " << "operatorGraph="; (obj.__isset.operatorGraph ? (out << to_string(obj.operatorGraph)) : (out << "<null>"));
+  out << ", " << "operatorList="; (obj.__isset.operatorList ? (out << to_string(obj.operatorList)) : (out << "<null>"));
+  out << ", " << "done=" << to_string(obj.done);
+  out << ", " << "started=" << to_string(obj.started);
+  out << ")";
+  return out;
+}
+
+
+Stage::~Stage() throw() {
+}
+
+
+void Stage::__set_stageId(const std::string& val) {
+  this->stageId = val;
+}
+
+void Stage::__set_stageType(const StageType::type val) {
+  this->stageType = val;
+}
+
+void Stage::__set_stageAttributes(const std::map<std::string, std::string> & val) {
+  this->stageAttributes = val;
+}
+
+void Stage::__set_stageCounters(const std::map<std::string, int64_t> & val) {
+  this->stageCounters = val;
+}
+
+void Stage::__set_taskList(const std::vector<Task> & val) {
+  this->taskList = val;
+}
+
+void Stage::__set_done(const bool val) {
+  this->done = val;
+}
+
+void Stage::__set_started(const bool val) {
+  this->started = val;
+}
+
 const char* Stage::ascii_fingerprint = "86EA3C7B0690AFED21A3D479E2B32378";
 const uint8_t Stage::binary_fingerprint[16] = {0x86,0xEA,0x3C,0x7B,0x06,0x90,0xAF,0xED,0x21,0xA3,0xD4,0x79,0xE2,0xB3,0x23,0x78};
 
@@ -803,9 +1067,9 @@ uint32_t Stage::read(::apache::thrift::protocol::TProtocol* iprot) {
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast60;
-          xfer += iprot->readI32(ecast60);
-          this->stageType = (StageType::type)ecast60;
+          int32_t ecast68;
+          xfer += iprot->readI32(ecast68);
+          this->stageType = (StageType::type)ecast68;
           this->__isset.stageType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -815,17 +1079,17 @@ uint32_t Stage::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->stageAttributes.clear();
-            uint32_t _size61;
-            ::apache::thrift::protocol::TType _ktype62;
-            ::apache::thrift::protocol::TType _vtype63;
-            xfer += iprot->readMapBegin(_ktype62, _vtype63, _size61);
-            uint32_t _i65;
-            for (_i65 = 0; _i65 < _size61; ++_i65)
+            uint32_t _size69;
+            ::apache::thrift::protocol::TType _ktype70;
+            ::apache::thrift::protocol::TType _vtype71;
+            xfer += iprot->readMapBegin(_ktype70, _vtype71, _size69);
+            uint32_t _i73;
+            for (_i73 = 0; _i73 < _size69; ++_i73)
             {
-              std::string _key66;
-              xfer += iprot->readString(_key66);
-              std::string& _val67 = this->stageAttributes[_key66];
-              xfer += iprot->readString(_val67);
+              std::string _key74;
+              xfer += iprot->readString(_key74);
+              std::string& _val75 = this->stageAttributes[_key74];
+              xfer += iprot->readString(_val75);
             }
             xfer += iprot->readMapEnd();
           }
@@ -838,17 +1102,17 @@ uint32_t Stage::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->stageCounters.clear();
-            uint32_t _size68;
-            ::apache::thrift::protocol::TType _ktype69;
-            ::apache::thrift::protocol::TType _vtype70;
-            xfer += iprot->readMapBegin(_ktype69, _vtype70, _size68);
-            uint32_t _i72;
-            for (_i72 = 0; _i72 < _size68; ++_i72)
+            uint32_t _size76;
+            ::apache::thrift::protocol::TType _ktype77;
+            ::apache::thrift::protocol::TType _vtype78;
+            xfer += iprot->readMapBegin(_ktype77, _vtype78, _size76);
+            uint32_t _i80;
+            for (_i80 = 0; _i80 < _size76; ++_i80)
             {
-              std::string _key73;
-              xfer += iprot->readString(_key73);
-              int64_t& _val74 = this->stageCounters[_key73];
-              xfer += iprot->readI64(_val74);
+              std::string _key81;
+              xfer += iprot->readString(_key81);
+              int64_t& _val82 = this->stageCounters[_key81];
+              xfer += iprot->readI64(_val82);
             }
             xfer += iprot->readMapEnd();
           }
@@ -861,14 +1125,14 @@ uint32_t Stage::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->taskList.clear();
-            uint32_t _size75;
-            ::apache::thrift::protocol::TType _etype78;
-            xfer += iprot->readListBegin(_etype78, _size75);
-            this->taskList.resize(_size75);
-            uint32_t _i79;
-            for (_i79 = 0; _i79 < _size75; ++_i79)
+            uint32_t _size83;
+            ::apache::thrift::protocol::TType _etype86;
+            xfer += iprot->readListBegin(_etype86, _size83);
+            this->taskList.resize(_size83);
+            uint32_t _i87;
+            for (_i87 = 0; _i87 < _size83; ++_i87)
             {
-              xfer += this->taskList[_i79].read(iprot);
+              xfer += this->taskList[_i87].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -907,6 +1171,7 @@ uint32_t Stage::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Stage::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Stage");
 
   xfer += oprot->writeFieldBegin("stageId", ::apache::thrift::protocol::T_STRING, 1);
@@ -920,11 +1185,11 @@ uint32_t Stage::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("stageAttributes", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->stageAttributes.size()));
-    std::map<std::string, std::string> ::const_iterator _iter80;
-    for (_iter80 = this->stageAttributes.begin(); _iter80 != this->stageAttributes.end(); ++_iter80)
+    std::map<std::string, std::string> ::const_iterator _iter88;
+    for (_iter88 = this->stageAttributes.begin(); _iter88 != this->stageAttributes.end(); ++_iter88)
     {
-      xfer += oprot->writeString(_iter80->first);
-      xfer += oprot->writeString(_iter80->second);
+      xfer += oprot->writeString(_iter88->first);
+      xfer += oprot->writeString(_iter88->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -933,11 +1198,11 @@ uint32_t Stage::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("stageCounters", ::apache::thrift::protocol::T_MAP, 4);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->stageCounters.size()));
-    std::map<std::string, int64_t> ::const_iterator _iter81;
-    for (_iter81 = this->stageCounters.begin(); _iter81 != this->stageCounters.end(); ++_iter81)
+    std::map<std::string, int64_t> ::const_iterator _iter89;
+    for (_iter89 = this->stageCounters.begin(); _iter89 != this->stageCounters.end(); ++_iter89)
     {
-      xfer += oprot->writeString(_iter81->first);
-      xfer += oprot->writeI64(_iter81->second);
+      xfer += oprot->writeString(_iter89->first);
+      xfer += oprot->writeI64(_iter89->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -946,10 +1211,10 @@ uint32_t Stage::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("taskList", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->taskList.size()));
-    std::vector<Task> ::const_iterator _iter82;
-    for (_iter82 = this->taskList.begin(); _iter82 != this->taskList.end(); ++_iter82)
+    std::vector<Task> ::const_iterator _iter90;
+    for (_iter90 = this->taskList.begin(); _iter90 != this->taskList.end(); ++_iter90)
     {
-      xfer += (*_iter82).write(oprot);
+      xfer += (*_iter90).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -965,6 +1230,7 @@ uint32_t Stage::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -980,6 +1246,78 @@ void swap(Stage &a, Stage &b) {
   swap(a.__isset, b.__isset);
 }
 
+Stage::Stage(const Stage& other91) {
+  stageId = other91.stageId;
+  stageType = other91.stageType;
+  stageAttributes = other91.stageAttributes;
+  stageCounters = other91.stageCounters;
+  taskList = other91.taskList;
+  done = other91.done;
+  started = other91.started;
+  __isset = other91.__isset;
+}
+Stage& Stage::operator=(const Stage& other92) {
+  stageId = other92.stageId;
+  stageType = other92.stageType;
+  stageAttributes = other92.stageAttributes;
+  stageCounters = other92.stageCounters;
+  taskList = other92.taskList;
+  done = other92.done;
+  started = other92.started;
+  __isset = other92.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Stage& obj) {
+  using apache::thrift::to_string;
+  out << "Stage(";
+  out << "stageId=" << to_string(obj.stageId);
+  out << ", " << "stageType=" << to_string(obj.stageType);
+  out << ", " << "stageAttributes=" << to_string(obj.stageAttributes);
+  out << ", " << "stageCounters=" << to_string(obj.stageCounters);
+  out << ", " << "taskList=" << to_string(obj.taskList);
+  out << ", " << "done=" << to_string(obj.done);
+  out << ", " << "started=" << to_string(obj.started);
+  out << ")";
+  return out;
+}
+
+
+Query::~Query() throw() {
+}
+
+
+void Query::__set_queryId(const std::string& val) {
+  this->queryId = val;
+}
+
+void Query::__set_queryType(const std::string& val) {
+  this->queryType = val;
+}
+
+void Query::__set_queryAttributes(const std::map<std::string, std::string> & val) {
+  this->queryAttributes = val;
+}
+
+void Query::__set_queryCounters(const std::map<std::string, int64_t> & val) {
+  this->queryCounters = val;
+}
+
+void Query::__set_stageGraph(const Graph& val) {
+  this->stageGraph = val;
+}
+
+void Query::__set_stageList(const std::vector<Stage> & val) {
+  this->stageList = val;
+}
+
+void Query::__set_done(const bool val) {
+  this->done = val;
+}
+
+void Query::__set_started(const bool val) {
+  this->started = val;
+}
+
 const char* Query::ascii_fingerprint = "68300D63A5D40F2D17B9A9440FF626C1";
 const uint8_t Query::binary_fingerprint[16] = {0x68,0x30,0x0D,0x63,0xA5,0xD4,0x0F,0x2D,0x17,0xB9,0xA9,0x44,0x0F,0xF6,0x26,0xC1};
 
@@ -1023,17 +1361,17 @@ uint32_t Query::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->queryAttributes.clear();
-            uint32_t _size83;
-            ::apache::thrift::protocol::TType _ktype84;
-            ::apache::thrift::protocol::TType _vtype85;
-            xfer += iprot->readMapBegin(_ktype84, _vtype85, _size83);
-            uint32_t _i87;
-            for (_i87 = 0; _i87 < _size83; ++_i87)
+            uint32_t _size93;
+            ::apache::thrift::protocol::TType _ktype94;
+            ::apache::thrift::protocol::TType _vtype95;
+            xfer += iprot->readMapBegin(_ktype94, _vtype95, _size93);
+            uint32_t _i97;
+            for (_i97 = 0; _i97 < _size93; ++_i97)
             {
-              std::string _key88;
-              xfer += iprot->readString(_key88);
-              std::string& _val89 = this->queryAttributes[_key88];
-              xfer += iprot->readString(_val89);
+              std::string _key98;
+              xfer += iprot->readString(_key98);
+              std::string& _val99 = this->queryAttributes[_key98];
+              xfer += iprot->readString(_val99);
             }
             xfer += iprot->readMapEnd();
           }
@@ -1046,17 +1384,17 @@ uint32_t Query::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->queryCounters.clear();
-            uint32_t _size90;
-            ::apache::thrift::protocol::TType _ktype91;
-            ::apache::thrift::protocol::TType _vtype92;
-            xfer += iprot->readMapBegin(_ktype91, _vtype92, _size90);
-            uint32_t _i94;
-            for (_i94 = 0; _i94 < _size90; ++_i94)
+            uint32_t _size100;
+            ::apache::thrift::protocol::TType _ktype101;
+            ::apache::thrift::protocol::TType _vtype102;
+            xfer += iprot->readMapBegin(_ktype101, _vtype102, _size100);
+            uint32_t _i104;
+            for (_i104 = 0; _i104 < _size100; ++_i104)
             {
-              std::string _key95;
-              xfer += iprot->readString(_key95);
-              int64_t& _val96 = this->queryCounters[_key95];
-              xfer += iprot->readI64(_val96);
+              std::string _key105;
+              xfer += iprot->readString(_key105);
+              int64_t& _val106 = this->queryCounters[_key105];
+              xfer += iprot->readI64(_val106);
             }
             xfer += iprot->readMapEnd();
           }
@@ -1077,14 +1415,14 @@ uint32_t Query::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->stageList.clear();
-            uint32_t _size97;
-            ::apache::thrift::protocol::TType _etype100;
-            xfer += iprot->readListBegin(_etype100, _size97);
-            this->stageList.resize(_size97);
-            uint32_t _i101;
-            for (_i101 = 0; _i101 < _size97; ++_i101)
+            uint32_t _size107;
+            ::apache::thrift::protocol::TType _etype110;
+            xfer += iprot->readListBegin(_etype110, _size107);
+            this->stageList.resize(_size107);
+            uint32_t _i111;
+            for (_i111 = 0; _i111 < _size107; ++_i111)
             {
-              xfer += this->stageList[_i101].read(iprot);
+              xfer += this->stageList[_i111].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1123,6 +1461,7 @@ uint32_t Query::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Query::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Query");
 
   xfer += oprot->writeFieldBegin("queryId", ::apache::thrift::protocol::T_STRING, 1);
@@ -1136,11 +1475,11 @@ uint32_t Query::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("queryAttributes", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->queryAttributes.size()));
-    std::map<std::string, std::string> ::const_iterator _iter102;
-    for (_iter102 = this->queryAttributes.begin(); _iter102 != this->queryAttributes.end(); ++_iter102)
+    std::map<std::string, std::string> ::const_iterator _iter112;
+    for (_iter112 = this->queryAttributes.begin(); _iter112 != this->queryAttributes.end(); ++_iter112)
     {
-      xfer += oprot->writeString(_iter102->first);
-      xfer += oprot->writeString(_iter102->second);
+      xfer += oprot->writeString(_iter112->first);
+      xfer += oprot->writeString(_iter112->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -1149,11 +1488,11 @@ uint32_t Query::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("queryCounters", ::apache::thrift::protocol::T_MAP, 4);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->queryCounters.size()));
-    std::map<std::string, int64_t> ::const_iterator _iter103;
-    for (_iter103 = this->queryCounters.begin(); _iter103 != this->queryCounters.end(); ++_iter103)
+    std::map<std::string, int64_t> ::const_iterator _iter113;
+    for (_iter113 = this->queryCounters.begin(); _iter113 != this->queryCounters.end(); ++_iter113)
     {
-      xfer += oprot->writeString(_iter103->first);
-      xfer += oprot->writeI64(_iter103->second);
+      xfer += oprot->writeString(_iter113->first);
+      xfer += oprot->writeI64(_iter113->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -1166,10 +1505,10 @@ uint32_t Query::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("stageList", ::apache::thrift::protocol::T_LIST, 6);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->stageList.size()));
-    std::vector<Stage> ::const_iterator _iter104;
-    for (_iter104 = this->stageList.begin(); _iter104 != this->stageList.end(); ++_iter104)
+    std::vector<Stage> ::const_iterator _iter114;
+    for (_iter114 = this->stageList.begin(); _iter114 != this->stageList.end(); ++_iter114)
     {
-      xfer += (*_iter104).write(oprot);
+      xfer += (*_iter114).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1185,6 +1524,7 @@ uint32_t Query::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1201,6 +1541,61 @@ void swap(Query &a, Query &b) {
   swap(a.__isset, b.__isset);
 }
 
+Query::Query(const Query& other115) {
+  queryId = other115.queryId;
+  queryType = other115.queryType;
+  queryAttributes = other115.queryAttributes;
+  queryCounters = other115.queryCounters;
+  stageGraph = other115.stageGraph;
+  stageList = other115.stageList;
+  done = other115.done;
+  started = other115.started;
+  __isset = other115.__isset;
+}
+Query& Query::operator=(const Query& other116) {
+  queryId = other116.queryId;
+  queryType = other116.queryType;
+  queryAttributes = other116.queryAttributes;
+  queryCounters = other116.queryCounters;
+  stageGraph = other116.stageGraph;
+  stageList = other116.stageList;
+  done = other116.done;
+  started = other116.started;
+  __isset = other116.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Query& obj) {
+  using apache::thrift::to_string;
+  out << "Query(";
+  out << "queryId=" << to_string(obj.queryId);
+  out << ", " << "queryType=" << to_string(obj.queryType);
+  out << ", " << "queryAttributes=" << to_string(obj.queryAttributes);
+  out << ", " << "queryCounters=" << to_string(obj.queryCounters);
+  out << ", " << "stageGraph=" << to_string(obj.stageGraph);
+  out << ", " << "stageList=" << to_string(obj.stageList);
+  out << ", " << "done=" << to_string(obj.done);
+  out << ", " << "started=" << to_string(obj.started);
+  out << ")";
+  return out;
+}
+
+
+QueryPlan::~QueryPlan() throw() {
+}
+
+
+void QueryPlan::__set_queries(const std::vector<Query> & val) {
+  this->queries = val;
+}
+
+void QueryPlan::__set_done(const bool val) {
+  this->done = val;
+}
+
+void QueryPlan::__set_started(const bool val) {
+  this->started = val;
+}
+
 const char* QueryPlan::ascii_fingerprint = "3418D1B0C20C288C8406186700B772E3";
 const uint8_t QueryPlan::binary_fingerprint[16] = {0x34,0x18,0xD1,0xB0,0xC2,0x0C,0x28,0x8C,0x84,0x06,0x18,0x67,0x00,0xB7,0x72,0xE3};
 
@@ -1228,14 +1623,14 @@ uint32_t QueryPlan::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->queries.clear();
-            uint32_t _size105;
-            ::apache::thrift::protocol::TType _etype108;
-            xfer += iprot->readListBegin(_etype108, _size105);
-            this->queries.resize(_size105);
-            uint32_t _i109;
-            for (_i109 = 0; _i109 < _size105; ++_i109)
+            uint32_t _size117;
+            ::apache::thrift::protocol::TType _etype120;
+            xfer += iprot->readListBegin(_etype120, _size117);
+            this->queries.resize(_size117);
+            uint32_t _i121;
+            for (_i121 = 0; _i121 < _size117; ++_i121)
             {
-              xfer += this->queries[_i109].read(iprot);
+              xfer += this->queries[_i121].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1274,15 +1669,16 @@ uint32_t QueryPlan::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t QueryPlan::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("QueryPlan");
 
   xfer += oprot->writeFieldBegin("queries", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->queries.size()));
-    std::vector<Query> ::const_iterator _iter110;
-    for (_iter110 = this->queries.begin(); _iter110 != this->queries.end(); ++_iter110)
+    std::vector<Query> ::const_iterator _iter122;
+    for (_iter122 = this->queries.begin(); _iter122 != this->queries.end(); ++_iter122)
     {
-      xfer += (*_iter110).write(oprot);
+      xfer += (*_iter122).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1298,6 +1694,7 @@ uint32_t QueryPlan::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1309,4 +1706,27 @@ void swap(QueryPlan &a, QueryPlan &b) {
   swap(a.__isset, b.__isset);
 }
 
+QueryPlan::QueryPlan(const QueryPlan& other123) {
+  queries = other123.queries;
+  done = other123.done;
+  started = other123.started;
+  __isset = other123.__isset;
+}
+QueryPlan& QueryPlan::operator=(const QueryPlan& other124) {
+  queries = other124.queries;
+  done = other124.done;
+  started = other124.started;
+  __isset = other124.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const QueryPlan& obj) {
+  using apache::thrift::to_string;
+  out << "QueryPlan(";
+  out << "queries=" << to_string(obj.queries);
+  out << ", " << "done=" << to_string(obj.done);
+  out << ", " << "started=" << to_string(obj.started);
+  out << ")";
+  return out;
+}
+
 }}} // namespace

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-cpp/queryplan_types.h
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-cpp/queryplan_types.h b/ql/src/gen/thrift/gen-cpp/queryplan_types.h
index ac73bc5..932804d 100644
--- a/ql/src/gen/thrift/gen-cpp/queryplan_types.h
+++ b/ql/src/gen/thrift/gen-cpp/queryplan_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef queryplan_TYPES_H
 #define queryplan_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 
 
 namespace Apache { namespace Hadoop { namespace Hive {
@@ -60,7 +63,8 @@ struct OperatorType {
     EVENT = 21,
     ORCFILEMERGE = 22,
     RCFILEMERGE = 23,
-    MERGEJOIN = 24
+    MERGEJOIN = 24,
+    SPARKPRUNINGSINK = 25
   };
 };
 
@@ -95,11 +99,25 @@ struct StageType {
 
 extern const std::map<int, const char*> _StageType_VALUES_TO_NAMES;
 
+class Adjacency;
+
+class Graph;
+
+class Operator;
+
+class Task;
+
+class Stage;
+
+class Query;
+
+class QueryPlan;
+
 typedef struct _Adjacency__isset {
   _Adjacency__isset() : node(false), children(false), adjacencyType(false) {}
-  bool node;
-  bool children;
-  bool adjacencyType;
+  bool node :1;
+  bool children :1;
+  bool adjacencyType :1;
 } _Adjacency__isset;
 
 class Adjacency {
@@ -108,28 +126,23 @@ class Adjacency {
   static const char* ascii_fingerprint; // = "BC4F8C394677A1003AA9F56ED26D8204";
   static const uint8_t binary_fingerprint[16]; // = {0xBC,0x4F,0x8C,0x39,0x46,0x77,0xA1,0x00,0x3A,0xA9,0xF5,0x6E,0xD2,0x6D,0x82,0x04};
 
+  Adjacency(const Adjacency&);
+  Adjacency& operator=(const Adjacency&);
   Adjacency() : node(), adjacencyType((AdjacencyType::type)0) {
   }
 
-  virtual ~Adjacency() throw() {}
-
+  virtual ~Adjacency() throw();
   std::string node;
   std::vector<std::string>  children;
   AdjacencyType::type adjacencyType;
 
   _Adjacency__isset __isset;
 
-  void __set_node(const std::string& val) {
-    node = val;
-  }
+  void __set_node(const std::string& val);
 
-  void __set_children(const std::vector<std::string> & val) {
-    children = val;
-  }
+  void __set_children(const std::vector<std::string> & val);
 
-  void __set_adjacencyType(const AdjacencyType::type val) {
-    adjacencyType = val;
-  }
+  void __set_adjacencyType(const AdjacencyType::type val);
 
   bool operator == (const Adjacency & rhs) const
   {
@@ -150,15 +163,16 @@ class Adjacency {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Adjacency& obj);
 };
 
 void swap(Adjacency &a, Adjacency &b);
 
 typedef struct _Graph__isset {
   _Graph__isset() : nodeType(false), roots(false), adjacencyList(false) {}
-  bool nodeType;
-  bool roots;
-  bool adjacencyList;
+  bool nodeType :1;
+  bool roots :1;
+  bool adjacencyList :1;
 } _Graph__isset;
 
 class Graph {
@@ -167,28 +181,23 @@ class Graph {
   static const char* ascii_fingerprint; // = "1F7FB604B3EF8F7AFB5DEAD15F2FC0B5";
   static const uint8_t binary_fingerprint[16]; // = {0x1F,0x7F,0xB6,0x04,0xB3,0xEF,0x8F,0x7A,0xFB,0x5D,0xEA,0xD1,0x5F,0x2F,0xC0,0xB5};
 
+  Graph(const Graph&);
+  Graph& operator=(const Graph&);
   Graph() : nodeType((NodeType::type)0) {
   }
 
-  virtual ~Graph() throw() {}
-
+  virtual ~Graph() throw();
   NodeType::type nodeType;
   std::vector<std::string>  roots;
   std::vector<Adjacency>  adjacencyList;
 
   _Graph__isset __isset;
 
-  void __set_nodeType(const NodeType::type val) {
-    nodeType = val;
-  }
+  void __set_nodeType(const NodeType::type val);
 
-  void __set_roots(const std::vector<std::string> & val) {
-    roots = val;
-  }
+  void __set_roots(const std::vector<std::string> & val);
 
-  void __set_adjacencyList(const std::vector<Adjacency> & val) {
-    adjacencyList = val;
-  }
+  void __set_adjacencyList(const std::vector<Adjacency> & val);
 
   bool operator == (const Graph & rhs) const
   {
@@ -209,18 +218,19 @@ class Graph {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Graph& obj);
 };
 
 void swap(Graph &a, Graph &b);
 
 typedef struct _Operator__isset {
   _Operator__isset() : operatorId(false), operatorType(false), operatorAttributes(false), operatorCounters(false), done(false), started(false) {}
-  bool operatorId;
-  bool operatorType;
-  bool operatorAttributes;
-  bool operatorCounters;
-  bool done;
-  bool started;
+  bool operatorId :1;
+  bool operatorType :1;
+  bool operatorAttributes :1;
+  bool operatorCounters :1;
+  bool done :1;
+  bool started :1;
 } _Operator__isset;
 
 class Operator {
@@ -229,11 +239,12 @@ class Operator {
   static const char* ascii_fingerprint; // = "30917C758A752485AF223B697479DE6C";
   static const uint8_t binary_fingerprint[16]; // = {0x30,0x91,0x7C,0x75,0x8A,0x75,0x24,0x85,0xAF,0x22,0x3B,0x69,0x74,0x79,0xDE,0x6C};
 
+  Operator(const Operator&);
+  Operator& operator=(const Operator&);
   Operator() : operatorId(), operatorType((OperatorType::type)0), done(0), started(0) {
   }
 
-  virtual ~Operator() throw() {}
-
+  virtual ~Operator() throw();
   std::string operatorId;
   OperatorType::type operatorType;
   std::map<std::string, std::string>  operatorAttributes;
@@ -243,29 +254,17 @@ class Operator {
 
   _Operator__isset __isset;
 
-  void __set_operatorId(const std::string& val) {
-    operatorId = val;
-  }
+  void __set_operatorId(const std::string& val);
 
-  void __set_operatorType(const OperatorType::type val) {
-    operatorType = val;
-  }
+  void __set_operatorType(const OperatorType::type val);
 
-  void __set_operatorAttributes(const std::map<std::string, std::string> & val) {
-    operatorAttributes = val;
-  }
+  void __set_operatorAttributes(const std::map<std::string, std::string> & val);
 
-  void __set_operatorCounters(const std::map<std::string, int64_t> & val) {
-    operatorCounters = val;
-  }
+  void __set_operatorCounters(const std::map<std::string, int64_t> & val);
 
-  void __set_done(const bool val) {
-    done = val;
-  }
+  void __set_done(const bool val);
 
-  void __set_started(const bool val) {
-    started = val;
-  }
+  void __set_started(const bool val);
 
   bool operator == (const Operator & rhs) const
   {
@@ -292,20 +291,21 @@ class Operator {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Operator& obj);
 };
 
 void swap(Operator &a, Operator &b);
 
 typedef struct _Task__isset {
   _Task__isset() : taskId(false), taskType(false), taskAttributes(false), taskCounters(false), operatorGraph(false), operatorList(false), done(false), started(false) {}
-  bool taskId;
-  bool taskType;
-  bool taskAttributes;
-  bool taskCounters;
-  bool operatorGraph;
-  bool operatorList;
-  bool done;
-  bool started;
+  bool taskId :1;
+  bool taskType :1;
+  bool taskAttributes :1;
+  bool taskCounters :1;
+  bool operatorGraph :1;
+  bool operatorList :1;
+  bool done :1;
+  bool started :1;
 } _Task__isset;
 
 class Task {
@@ -314,11 +314,12 @@ class Task {
   static const char* ascii_fingerprint; // = "AC741A136EFA51843AFC3A12F6A793D1";
   static const uint8_t binary_fingerprint[16]; // = {0xAC,0x74,0x1A,0x13,0x6E,0xFA,0x51,0x84,0x3A,0xFC,0x3A,0x12,0xF6,0xA7,0x93,0xD1};
 
+  Task(const Task&);
+  Task& operator=(const Task&);
   Task() : taskId(), taskType((TaskType::type)0), done(0), started(0) {
   }
 
-  virtual ~Task() throw() {}
-
+  virtual ~Task() throw();
   std::string taskId;
   TaskType::type taskType;
   std::map<std::string, std::string>  taskAttributes;
@@ -330,39 +331,21 @@ class Task {
 
   _Task__isset __isset;
 
-  void __set_taskId(const std::string& val) {
-    taskId = val;
-  }
+  void __set_taskId(const std::string& val);
 
-  void __set_taskType(const TaskType::type val) {
-    taskType = val;
-  }
+  void __set_taskType(const TaskType::type val);
 
-  void __set_taskAttributes(const std::map<std::string, std::string> & val) {
-    taskAttributes = val;
-  }
+  void __set_taskAttributes(const std::map<std::string, std::string> & val);
 
-  void __set_taskCounters(const std::map<std::string, int64_t> & val) {
-    taskCounters = val;
-  }
+  void __set_taskCounters(const std::map<std::string, int64_t> & val);
 
-  void __set_operatorGraph(const Graph& val) {
-    operatorGraph = val;
-    __isset.operatorGraph = true;
-  }
+  void __set_operatorGraph(const Graph& val);
 
-  void __set_operatorList(const std::vector<Operator> & val) {
-    operatorList = val;
-    __isset.operatorList = true;
-  }
+  void __set_operatorList(const std::vector<Operator> & val);
 
-  void __set_done(const bool val) {
-    done = val;
-  }
+  void __set_done(const bool val);
 
-  void __set_started(const bool val) {
-    started = val;
-  }
+  void __set_started(const bool val);
 
   bool operator == (const Task & rhs) const
   {
@@ -397,19 +380,20 @@ class Task {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Task& obj);
 };
 
 void swap(Task &a, Task &b);
 
 typedef struct _Stage__isset {
   _Stage__isset() : stageId(false), stageType(false), stageAttributes(false), stageCounters(false), taskList(false), done(false), started(false) {}
-  bool stageId;
-  bool stageType;
-  bool stageAttributes;
-  bool stageCounters;
-  bool taskList;
-  bool done;
-  bool started;
+  bool stageId :1;
+  bool stageType :1;
+  bool stageAttributes :1;
+  bool stageCounters :1;
+  bool taskList :1;
+  bool done :1;
+  bool started :1;
 } _Stage__isset;
 
 class Stage {
@@ -418,11 +402,12 @@ class Stage {
   static const char* ascii_fingerprint; // = "86EA3C7B0690AFED21A3D479E2B32378";
   static const uint8_t binary_fingerprint[16]; // = {0x86,0xEA,0x3C,0x7B,0x06,0x90,0xAF,0xED,0x21,0xA3,0xD4,0x79,0xE2,0xB3,0x23,0x78};
 
+  Stage(const Stage&);
+  Stage& operator=(const Stage&);
   Stage() : stageId(), stageType((StageType::type)0), done(0), started(0) {
   }
 
-  virtual ~Stage() throw() {}
-
+  virtual ~Stage() throw();
   std::string stageId;
   StageType::type stageType;
   std::map<std::string, std::string>  stageAttributes;
@@ -433,33 +418,19 @@ class Stage {
 
   _Stage__isset __isset;
 
-  void __set_stageId(const std::string& val) {
-    stageId = val;
-  }
+  void __set_stageId(const std::string& val);
 
-  void __set_stageType(const StageType::type val) {
-    stageType = val;
-  }
+  void __set_stageType(const StageType::type val);
 
-  void __set_stageAttributes(const std::map<std::string, std::string> & val) {
-    stageAttributes = val;
-  }
+  void __set_stageAttributes(const std::map<std::string, std::string> & val);
 
-  void __set_stageCounters(const std::map<std::string, int64_t> & val) {
-    stageCounters = val;
-  }
+  void __set_stageCounters(const std::map<std::string, int64_t> & val);
 
-  void __set_taskList(const std::vector<Task> & val) {
-    taskList = val;
-  }
+  void __set_taskList(const std::vector<Task> & val);
 
-  void __set_done(const bool val) {
-    done = val;
-  }
+  void __set_done(const bool val);
 
-  void __set_started(const bool val) {
-    started = val;
-  }
+  void __set_started(const bool val);
 
   bool operator == (const Stage & rhs) const
   {
@@ -488,20 +459,21 @@ class Stage {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Stage& obj);
 };
 
 void swap(Stage &a, Stage &b);
 
 typedef struct _Query__isset {
   _Query__isset() : queryId(false), queryType(false), queryAttributes(false), queryCounters(false), stageGraph(false), stageList(false), done(false), started(false) {}
-  bool queryId;
-  bool queryType;
-  bool queryAttributes;
-  bool queryCounters;
-  bool stageGraph;
-  bool stageList;
-  bool done;
-  bool started;
+  bool queryId :1;
+  bool queryType :1;
+  bool queryAttributes :1;
+  bool queryCounters :1;
+  bool stageGraph :1;
+  bool stageList :1;
+  bool done :1;
+  bool started :1;
 } _Query__isset;
 
 class Query {
@@ -510,11 +482,12 @@ class Query {
   static const char* ascii_fingerprint; // = "68300D63A5D40F2D17B9A9440FF626C1";
   static const uint8_t binary_fingerprint[16]; // = {0x68,0x30,0x0D,0x63,0xA5,0xD4,0x0F,0x2D,0x17,0xB9,0xA9,0x44,0x0F,0xF6,0x26,0xC1};
 
+  Query(const Query&);
+  Query& operator=(const Query&);
   Query() : queryId(), queryType(), done(0), started(0) {
   }
 
-  virtual ~Query() throw() {}
-
+  virtual ~Query() throw();
   std::string queryId;
   std::string queryType;
   std::map<std::string, std::string>  queryAttributes;
@@ -526,37 +499,21 @@ class Query {
 
   _Query__isset __isset;
 
-  void __set_queryId(const std::string& val) {
-    queryId = val;
-  }
+  void __set_queryId(const std::string& val);
 
-  void __set_queryType(const std::string& val) {
-    queryType = val;
-  }
+  void __set_queryType(const std::string& val);
 
-  void __set_queryAttributes(const std::map<std::string, std::string> & val) {
-    queryAttributes = val;
-  }
+  void __set_queryAttributes(const std::map<std::string, std::string> & val);
 
-  void __set_queryCounters(const std::map<std::string, int64_t> & val) {
-    queryCounters = val;
-  }
+  void __set_queryCounters(const std::map<std::string, int64_t> & val);
 
-  void __set_stageGraph(const Graph& val) {
-    stageGraph = val;
-  }
+  void __set_stageGraph(const Graph& val);
 
-  void __set_stageList(const std::vector<Stage> & val) {
-    stageList = val;
-  }
+  void __set_stageList(const std::vector<Stage> & val);
 
-  void __set_done(const bool val) {
-    done = val;
-  }
+  void __set_done(const bool val);
 
-  void __set_started(const bool val) {
-    started = val;
-  }
+  void __set_started(const bool val);
 
   bool operator == (const Query & rhs) const
   {
@@ -587,15 +544,16 @@ class Query {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Query& obj);
 };
 
 void swap(Query &a, Query &b);
 
 typedef struct _QueryPlan__isset {
   _QueryPlan__isset() : queries(false), done(false), started(false) {}
-  bool queries;
-  bool done;
-  bool started;
+  bool queries :1;
+  bool done :1;
+  bool started :1;
 } _QueryPlan__isset;
 
 class QueryPlan {
@@ -604,28 +562,23 @@ class QueryPlan {
   static const char* ascii_fingerprint; // = "3418D1B0C20C288C8406186700B772E3";
   static const uint8_t binary_fingerprint[16]; // = {0x34,0x18,0xD1,0xB0,0xC2,0x0C,0x28,0x8C,0x84,0x06,0x18,0x67,0x00,0xB7,0x72,0xE3};
 
+  QueryPlan(const QueryPlan&);
+  QueryPlan& operator=(const QueryPlan&);
   QueryPlan() : done(0), started(0) {
   }
 
-  virtual ~QueryPlan() throw() {}
-
+  virtual ~QueryPlan() throw();
   std::vector<Query>  queries;
   bool done;
   bool started;
 
   _QueryPlan__isset __isset;
 
-  void __set_queries(const std::vector<Query> & val) {
-    queries = val;
-  }
+  void __set_queries(const std::vector<Query> & val);
 
-  void __set_done(const bool val) {
-    done = val;
-  }
+  void __set_done(const bool val);
 
-  void __set_started(const bool val) {
-    started = val;
-  }
+  void __set_started(const bool val);
 
   bool operator == (const QueryPlan & rhs) const
   {
@@ -646,6 +599,7 @@ class QueryPlan {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const QueryPlan& obj);
 };
 
 void swap(QueryPlan &a, QueryPlan &b);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Adjacency.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Adjacency.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Adjacency.java
index 22ca225..b71f4ae 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Adjacency.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Adjacency.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._Fields>, java.io.Serializable, Cloneable, Comparable<Adjacency> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Adjacency");
 
   private static final org.apache.thrift.protocol.TField NODE_FIELD_DESC = new org.apache.thrift.protocol.TField("node", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -153,10 +157,7 @@ public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._
       this.node = other.node;
     }
     if (other.isSetChildren()) {
-      List<String> __this__children = new ArrayList<String>();
-      for (String other_element : other.children) {
-        __this__children.add(other_element);
-      }
+      List<String> __this__children = new ArrayList<String>(other.children);
       this.children = __this__children;
     }
     if (other.isSetAdjacencyType()) {
@@ -373,60 +374,60 @@ public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_node = true && (isSetNode());
-    builder.append(present_node);
+    list.add(present_node);
     if (present_node)
-      builder.append(node);
+      list.add(node);
 
     boolean present_children = true && (isSetChildren());
-    builder.append(present_children);
+    list.add(present_children);
     if (present_children)
-      builder.append(children);
+      list.add(children);
 
     boolean present_adjacencyType = true && (isSetAdjacencyType());
-    builder.append(present_adjacencyType);
+    list.add(present_adjacencyType);
     if (present_adjacencyType)
-      builder.append(adjacencyType.getValue());
+      list.add(adjacencyType.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Adjacency other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Adjacency typedOther = (Adjacency)other;
 
-    lastComparison = Boolean.valueOf(isSetNode()).compareTo(typedOther.isSetNode());
+    lastComparison = Boolean.valueOf(isSetNode()).compareTo(other.isSetNode());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNode()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.node, typedOther.node);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.node, other.node);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetChildren()).compareTo(typedOther.isSetChildren());
+    lastComparison = Boolean.valueOf(isSetChildren()).compareTo(other.isSetChildren());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetChildren()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.children, typedOther.children);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.children, other.children);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAdjacencyType()).compareTo(typedOther.isSetAdjacencyType());
+    lastComparison = Boolean.valueOf(isSetAdjacencyType()).compareTo(other.isSetAdjacencyType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAdjacencyType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.adjacencyType, typedOther.adjacencyType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.adjacencyType, other.adjacencyType);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -530,11 +531,11 @@ public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._
               {
                 org.apache.thrift.protocol.TList _list0 = iprot.readListBegin();
                 struct.children = new ArrayList<String>(_list0.size);
-                for (int _i1 = 0; _i1 < _list0.size; ++_i1)
+                String _elem1;
+                for (int _i2 = 0; _i2 < _list0.size; ++_i2)
                 {
-                  String _elem2; // required
-                  _elem2 = iprot.readString();
-                  struct.children.add(_elem2);
+                  _elem1 = iprot.readString();
+                  struct.children.add(_elem1);
                 }
                 iprot.readListEnd();
               }
@@ -545,7 +546,7 @@ public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._
             break;
           case 3: // ADJACENCY_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.adjacencyType = AdjacencyType.findByValue(iprot.readI32());
+              struct.adjacencyType = org.apache.hadoop.hive.ql.plan.api.AdjacencyType.findByValue(iprot.readI32());
               struct.setAdjacencyTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -643,17 +644,17 @@ public class Adjacency implements org.apache.thrift.TBase<Adjacency, Adjacency._
         {
           org.apache.thrift.protocol.TList _list5 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.children = new ArrayList<String>(_list5.size);
-          for (int _i6 = 0; _i6 < _list5.size; ++_i6)
+          String _elem6;
+          for (int _i7 = 0; _i7 < _list5.size; ++_i7)
           {
-            String _elem7; // required
-            _elem7 = iprot.readString();
-            struct.children.add(_elem7);
+            _elem6 = iprot.readString();
+            struct.children.add(_elem6);
           }
         }
         struct.setChildrenIsSet(true);
       }
       if (incoming.get(2)) {
-        struct.adjacencyType = AdjacencyType.findByValue(iprot.readI32());
+        struct.adjacencyType = org.apache.hadoop.hive.ql.plan.api.AdjacencyType.findByValue(iprot.readI32());
         struct.setAdjacencyTypeIsSet(true);
       }
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/AdjacencyType.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/AdjacencyType.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/AdjacencyType.java
index 7984d4e..470cad2 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/AdjacencyType.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/AdjacencyType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Graph.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Graph.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Graph.java
index 35aa6cb..d02c86d 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Graph.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Graph.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, java.io.Serializable, Cloneable, Comparable<Graph> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Graph");
 
   private static final org.apache.thrift.protocol.TField NODE_TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("nodeType", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -154,14 +158,11 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
       this.nodeType = other.nodeType;
     }
     if (other.isSetRoots()) {
-      List<String> __this__roots = new ArrayList<String>();
-      for (String other_element : other.roots) {
-        __this__roots.add(other_element);
-      }
+      List<String> __this__roots = new ArrayList<String>(other.roots);
       this.roots = __this__roots;
     }
     if (other.isSetAdjacencyList()) {
-      List<Adjacency> __this__adjacencyList = new ArrayList<Adjacency>();
+      List<Adjacency> __this__adjacencyList = new ArrayList<Adjacency>(other.adjacencyList.size());
       for (Adjacency other_element : other.adjacencyList) {
         __this__adjacencyList.add(new Adjacency(other_element));
       }
@@ -393,60 +394,60 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_nodeType = true && (isSetNodeType());
-    builder.append(present_nodeType);
+    list.add(present_nodeType);
     if (present_nodeType)
-      builder.append(nodeType.getValue());
+      list.add(nodeType.getValue());
 
     boolean present_roots = true && (isSetRoots());
-    builder.append(present_roots);
+    list.add(present_roots);
     if (present_roots)
-      builder.append(roots);
+      list.add(roots);
 
     boolean present_adjacencyList = true && (isSetAdjacencyList());
-    builder.append(present_adjacencyList);
+    list.add(present_adjacencyList);
     if (present_adjacencyList)
-      builder.append(adjacencyList);
+      list.add(adjacencyList);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Graph other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Graph typedOther = (Graph)other;
 
-    lastComparison = Boolean.valueOf(isSetNodeType()).compareTo(typedOther.isSetNodeType());
+    lastComparison = Boolean.valueOf(isSetNodeType()).compareTo(other.isSetNodeType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNodeType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nodeType, typedOther.nodeType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nodeType, other.nodeType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRoots()).compareTo(typedOther.isSetRoots());
+    lastComparison = Boolean.valueOf(isSetRoots()).compareTo(other.isSetRoots());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRoots()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roots, typedOther.roots);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roots, other.roots);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAdjacencyList()).compareTo(typedOther.isSetAdjacencyList());
+    lastComparison = Boolean.valueOf(isSetAdjacencyList()).compareTo(other.isSetAdjacencyList());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAdjacencyList()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.adjacencyList, typedOther.adjacencyList);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.adjacencyList, other.adjacencyList);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -539,7 +540,7 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
         switch (schemeField.id) {
           case 1: // NODE_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.nodeType = NodeType.findByValue(iprot.readI32());
+              struct.nodeType = org.apache.hadoop.hive.ql.plan.api.NodeType.findByValue(iprot.readI32());
               struct.setNodeTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -550,11 +551,11 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
               {
                 org.apache.thrift.protocol.TList _list8 = iprot.readListBegin();
                 struct.roots = new ArrayList<String>(_list8.size);
-                for (int _i9 = 0; _i9 < _list8.size; ++_i9)
+                String _elem9;
+                for (int _i10 = 0; _i10 < _list8.size; ++_i10)
                 {
-                  String _elem10; // required
-                  _elem10 = iprot.readString();
-                  struct.roots.add(_elem10);
+                  _elem9 = iprot.readString();
+                  struct.roots.add(_elem9);
                 }
                 iprot.readListEnd();
               }
@@ -568,12 +569,12 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
               {
                 org.apache.thrift.protocol.TList _list11 = iprot.readListBegin();
                 struct.adjacencyList = new ArrayList<Adjacency>(_list11.size);
-                for (int _i12 = 0; _i12 < _list11.size; ++_i12)
+                Adjacency _elem12;
+                for (int _i13 = 0; _i13 < _list11.size; ++_i13)
                 {
-                  Adjacency _elem13; // required
-                  _elem13 = new Adjacency();
-                  _elem13.read(iprot);
-                  struct.adjacencyList.add(_elem13);
+                  _elem12 = new Adjacency();
+                  _elem12.read(iprot);
+                  struct.adjacencyList.add(_elem12);
                 }
                 iprot.readListEnd();
               }
@@ -680,18 +681,18 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
       TTupleProtocol iprot = (TTupleProtocol) prot;
       BitSet incoming = iprot.readBitSet(3);
       if (incoming.get(0)) {
-        struct.nodeType = NodeType.findByValue(iprot.readI32());
+        struct.nodeType = org.apache.hadoop.hive.ql.plan.api.NodeType.findByValue(iprot.readI32());
         struct.setNodeTypeIsSet(true);
       }
       if (incoming.get(1)) {
         {
           org.apache.thrift.protocol.TList _list18 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.roots = new ArrayList<String>(_list18.size);
-          for (int _i19 = 0; _i19 < _list18.size; ++_i19)
+          String _elem19;
+          for (int _i20 = 0; _i20 < _list18.size; ++_i20)
           {
-            String _elem20; // required
-            _elem20 = iprot.readString();
-            struct.roots.add(_elem20);
+            _elem19 = iprot.readString();
+            struct.roots.add(_elem19);
           }
         }
         struct.setRootsIsSet(true);
@@ -700,12 +701,12 @@ public class Graph implements org.apache.thrift.TBase<Graph, Graph._Fields>, jav
         {
           org.apache.thrift.protocol.TList _list21 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.adjacencyList = new ArrayList<Adjacency>(_list21.size);
-          for (int _i22 = 0; _i22 < _list21.size; ++_i22)
+          Adjacency _elem22;
+          for (int _i23 = 0; _i23 < _list21.size; ++_i23)
           {
-            Adjacency _elem23; // required
-            _elem23 = new Adjacency();
-            _elem23.read(iprot);
-            struct.adjacencyList.add(_elem23);
+            _elem22 = new Adjacency();
+            _elem22.read(iprot);
+            struct.adjacencyList.add(_elem22);
           }
         }
         struct.setAdjacencyListIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/NodeType.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/NodeType.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/NodeType.java
index 1126049..5fdbfa3 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/NodeType.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/NodeType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[34/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SkewedInfo.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SkewedInfo.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SkewedInfo.java
index ab5c0ed..f1a3c0a 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SkewedInfo.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SkewedInfo.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInfo._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInfo._Fields>, java.io.Serializable, Cloneable, Comparable<SkewedInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("SkewedInfo");
 
   private static final org.apache.thrift.protocol.TField SKEWED_COL_NAMES_FIELD_DESC = new org.apache.thrift.protocol.TField("skewedColNames", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -151,34 +155,25 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
    */
   public SkewedInfo(SkewedInfo other) {
     if (other.isSetSkewedColNames()) {
-      List<String> __this__skewedColNames = new ArrayList<String>();
-      for (String other_element : other.skewedColNames) {
-        __this__skewedColNames.add(other_element);
-      }
+      List<String> __this__skewedColNames = new ArrayList<String>(other.skewedColNames);
       this.skewedColNames = __this__skewedColNames;
     }
     if (other.isSetSkewedColValues()) {
-      List<List<String>> __this__skewedColValues = new ArrayList<List<String>>();
+      List<List<String>> __this__skewedColValues = new ArrayList<List<String>>(other.skewedColValues.size());
       for (List<String> other_element : other.skewedColValues) {
-        List<String> __this__skewedColValues_copy = new ArrayList<String>();
-        for (String other_element_element : other_element) {
-          __this__skewedColValues_copy.add(other_element_element);
-        }
+        List<String> __this__skewedColValues_copy = new ArrayList<String>(other_element);
         __this__skewedColValues.add(__this__skewedColValues_copy);
       }
       this.skewedColValues = __this__skewedColValues;
     }
     if (other.isSetSkewedColValueLocationMaps()) {
-      Map<List<String>,String> __this__skewedColValueLocationMaps = new HashMap<List<String>,String>();
+      Map<List<String>,String> __this__skewedColValueLocationMaps = new HashMap<List<String>,String>(other.skewedColValueLocationMaps.size());
       for (Map.Entry<List<String>, String> other_element : other.skewedColValueLocationMaps.entrySet()) {
 
         List<String> other_element_key = other_element.getKey();
         String other_element_value = other_element.getValue();
 
-        List<String> __this__skewedColValueLocationMaps_copy_key = new ArrayList<String>();
-        for (String other_element_key_element : other_element_key) {
-          __this__skewedColValueLocationMaps_copy_key.add(other_element_key_element);
-        }
+        List<String> __this__skewedColValueLocationMaps_copy_key = new ArrayList<String>(other_element_key);
 
         String __this__skewedColValueLocationMaps_copy_value = other_element_value;
 
@@ -415,60 +410,60 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_skewedColNames = true && (isSetSkewedColNames());
-    builder.append(present_skewedColNames);
+    list.add(present_skewedColNames);
     if (present_skewedColNames)
-      builder.append(skewedColNames);
+      list.add(skewedColNames);
 
     boolean present_skewedColValues = true && (isSetSkewedColValues());
-    builder.append(present_skewedColValues);
+    list.add(present_skewedColValues);
     if (present_skewedColValues)
-      builder.append(skewedColValues);
+      list.add(skewedColValues);
 
     boolean present_skewedColValueLocationMaps = true && (isSetSkewedColValueLocationMaps());
-    builder.append(present_skewedColValueLocationMaps);
+    list.add(present_skewedColValueLocationMaps);
     if (present_skewedColValueLocationMaps)
-      builder.append(skewedColValueLocationMaps);
+      list.add(skewedColValueLocationMaps);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(SkewedInfo other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    SkewedInfo typedOther = (SkewedInfo)other;
 
-    lastComparison = Boolean.valueOf(isSetSkewedColNames()).compareTo(typedOther.isSetSkewedColNames());
+    lastComparison = Boolean.valueOf(isSetSkewedColNames()).compareTo(other.isSetSkewedColNames());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSkewedColNames()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColNames, typedOther.skewedColNames);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColNames, other.skewedColNames);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSkewedColValues()).compareTo(typedOther.isSetSkewedColValues());
+    lastComparison = Boolean.valueOf(isSetSkewedColValues()).compareTo(other.isSetSkewedColValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSkewedColValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColValues, typedOther.skewedColValues);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColValues, other.skewedColValues);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSkewedColValueLocationMaps()).compareTo(typedOther.isSetSkewedColValueLocationMaps());
+    lastComparison = Boolean.valueOf(isSetSkewedColValueLocationMaps()).compareTo(other.isSetSkewedColValueLocationMaps());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSkewedColValueLocationMaps()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColValueLocationMaps, typedOther.skewedColValueLocationMaps);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedColValueLocationMaps, other.skewedColValueLocationMaps);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -564,11 +559,11 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
               {
                 org.apache.thrift.protocol.TList _list114 = iprot.readListBegin();
                 struct.skewedColNames = new ArrayList<String>(_list114.size);
-                for (int _i115 = 0; _i115 < _list114.size; ++_i115)
+                String _elem115;
+                for (int _i116 = 0; _i116 < _list114.size; ++_i116)
                 {
-                  String _elem116; // optional
-                  _elem116 = iprot.readString();
-                  struct.skewedColNames.add(_elem116);
+                  _elem115 = iprot.readString();
+                  struct.skewedColNames.add(_elem115);
                 }
                 iprot.readListEnd();
               }
@@ -582,21 +577,21 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
               {
                 org.apache.thrift.protocol.TList _list117 = iprot.readListBegin();
                 struct.skewedColValues = new ArrayList<List<String>>(_list117.size);
-                for (int _i118 = 0; _i118 < _list117.size; ++_i118)
+                List<String> _elem118;
+                for (int _i119 = 0; _i119 < _list117.size; ++_i119)
                 {
-                  List<String> _elem119; // optional
                   {
                     org.apache.thrift.protocol.TList _list120 = iprot.readListBegin();
-                    _elem119 = new ArrayList<String>(_list120.size);
-                    for (int _i121 = 0; _i121 < _list120.size; ++_i121)
+                    _elem118 = new ArrayList<String>(_list120.size);
+                    String _elem121;
+                    for (int _i122 = 0; _i122 < _list120.size; ++_i122)
                     {
-                      String _elem122; // optional
-                      _elem122 = iprot.readString();
-                      _elem119.add(_elem122);
+                      _elem121 = iprot.readString();
+                      _elem118.add(_elem121);
                     }
                     iprot.readListEnd();
                   }
-                  struct.skewedColValues.add(_elem119);
+                  struct.skewedColValues.add(_elem118);
                 }
                 iprot.readListEnd();
               }
@@ -610,23 +605,23 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
               {
                 org.apache.thrift.protocol.TMap _map123 = iprot.readMapBegin();
                 struct.skewedColValueLocationMaps = new HashMap<List<String>,String>(2*_map123.size);
-                for (int _i124 = 0; _i124 < _map123.size; ++_i124)
+                List<String> _key124;
+                String _val125;
+                for (int _i126 = 0; _i126 < _map123.size; ++_i126)
                 {
-                  List<String> _key125; // required
-                  String _val126; // required
                   {
                     org.apache.thrift.protocol.TList _list127 = iprot.readListBegin();
-                    _key125 = new ArrayList<String>(_list127.size);
-                    for (int _i128 = 0; _i128 < _list127.size; ++_i128)
+                    _key124 = new ArrayList<String>(_list127.size);
+                    String _elem128;
+                    for (int _i129 = 0; _i129 < _list127.size; ++_i129)
                     {
-                      String _elem129; // optional
-                      _elem129 = iprot.readString();
-                      _key125.add(_elem129);
+                      _elem128 = iprot.readString();
+                      _key124.add(_elem128);
                     }
                     iprot.readListEnd();
                   }
-                  _val126 = iprot.readString();
-                  struct.skewedColValueLocationMaps.put(_key125, _val126);
+                  _val125 = iprot.readString();
+                  struct.skewedColValueLocationMaps.put(_key124, _val125);
                 }
                 iprot.readMapEnd();
               }
@@ -777,11 +772,11 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
         {
           org.apache.thrift.protocol.TList _list140 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.skewedColNames = new ArrayList<String>(_list140.size);
-          for (int _i141 = 0; _i141 < _list140.size; ++_i141)
+          String _elem141;
+          for (int _i142 = 0; _i142 < _list140.size; ++_i142)
           {
-            String _elem142; // optional
-            _elem142 = iprot.readString();
-            struct.skewedColNames.add(_elem142);
+            _elem141 = iprot.readString();
+            struct.skewedColNames.add(_elem141);
           }
         }
         struct.setSkewedColNamesIsSet(true);
@@ -790,20 +785,20 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
         {
           org.apache.thrift.protocol.TList _list143 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.skewedColValues = new ArrayList<List<String>>(_list143.size);
-          for (int _i144 = 0; _i144 < _list143.size; ++_i144)
+          List<String> _elem144;
+          for (int _i145 = 0; _i145 < _list143.size; ++_i145)
           {
-            List<String> _elem145; // optional
             {
               org.apache.thrift.protocol.TList _list146 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-              _elem145 = new ArrayList<String>(_list146.size);
-              for (int _i147 = 0; _i147 < _list146.size; ++_i147)
+              _elem144 = new ArrayList<String>(_list146.size);
+              String _elem147;
+              for (int _i148 = 0; _i148 < _list146.size; ++_i148)
               {
-                String _elem148; // optional
-                _elem148 = iprot.readString();
-                _elem145.add(_elem148);
+                _elem147 = iprot.readString();
+                _elem144.add(_elem147);
               }
             }
-            struct.skewedColValues.add(_elem145);
+            struct.skewedColValues.add(_elem144);
           }
         }
         struct.setSkewedColValuesIsSet(true);
@@ -812,22 +807,22 @@ public class SkewedInfo implements org.apache.thrift.TBase<SkewedInfo, SkewedInf
         {
           org.apache.thrift.protocol.TMap _map149 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.LIST, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.skewedColValueLocationMaps = new HashMap<List<String>,String>(2*_map149.size);
-          for (int _i150 = 0; _i150 < _map149.size; ++_i150)
+          List<String> _key150;
+          String _val151;
+          for (int _i152 = 0; _i152 < _map149.size; ++_i152)
           {
-            List<String> _key151; // required
-            String _val152; // required
             {
               org.apache.thrift.protocol.TList _list153 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-              _key151 = new ArrayList<String>(_list153.size);
-              for (int _i154 = 0; _i154 < _list153.size; ++_i154)
+              _key150 = new ArrayList<String>(_list153.size);
+              String _elem154;
+              for (int _i155 = 0; _i155 < _list153.size; ++_i155)
               {
-                String _elem155; // optional
-                _elem155 = iprot.readString();
-                _key151.add(_elem155);
+                _elem154 = iprot.readString();
+                _key150.add(_elem154);
               }
             }
-            _val152 = iprot.readString();
-            struct.skewedColValueLocationMaps.put(_key151, _val152);
+            _val151 = iprot.readString();
+            struct.skewedColValueLocationMaps.put(_key150, _val151);
           }
         }
         struct.setSkewedColValueLocationMapsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StorageDescriptor.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StorageDescriptor.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StorageDescriptor.java
index 813b4f0..13e85e6 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StorageDescriptor.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StorageDescriptor.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescriptor, StorageDescriptor._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescriptor, StorageDescriptor._Fields>, java.io.Serializable, Cloneable, Comparable<StorageDescriptor> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("StorageDescriptor");
 
   private static final org.apache.thrift.protocol.TField COLS_FIELD_DESC = new org.apache.thrift.protocol.TField("cols", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -162,7 +166,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   private static final int __NUMBUCKETS_ISSET_ID = 1;
   private static final int __STOREDASSUBDIRECTORIES_ISSET_ID = 2;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.SKEWED_INFO,_Fields.STORED_AS_SUB_DIRECTORIES};
+  private static final _Fields optionals[] = {_Fields.SKEWED_INFO,_Fields.STORED_AS_SUB_DIRECTORIES};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -216,17 +220,17 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   {
     this();
     this.cols = cols;
-    this.location = location;
-    this.inputFormat = inputFormat;
-    this.outputFormat = outputFormat;
+    this.location = org.apache.hive.common.util.HiveStringUtils.intern(location);
+    this.inputFormat = org.apache.hive.common.util.HiveStringUtils.intern(inputFormat);
+    this.outputFormat = org.apache.hive.common.util.HiveStringUtils.intern(outputFormat);
     this.compressed = compressed;
     setCompressedIsSet(true);
     this.numBuckets = numBuckets;
     setNumBucketsIsSet(true);
     this.serdeInfo = serdeInfo;
-    this.bucketCols = bucketCols;
+    this.bucketCols = org.apache.hive.common.util.HiveStringUtils.intern(bucketCols);
     this.sortCols = sortCols;
-    this.parameters = parameters;
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   /**
@@ -235,20 +239,20 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   public StorageDescriptor(StorageDescriptor other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetCols()) {
-      List<FieldSchema> __this__cols = new ArrayList<FieldSchema>();
+      List<FieldSchema> __this__cols = new ArrayList<FieldSchema>(other.cols.size());
       for (FieldSchema other_element : other.cols) {
         __this__cols.add(new FieldSchema(other_element));
       }
       this.cols = __this__cols;
     }
     if (other.isSetLocation()) {
-      this.location = other.location;
+      this.location = org.apache.hive.common.util.HiveStringUtils.intern(other.location);
     }
     if (other.isSetInputFormat()) {
-      this.inputFormat = other.inputFormat;
+      this.inputFormat = org.apache.hive.common.util.HiveStringUtils.intern(other.inputFormat);
     }
     if (other.isSetOutputFormat()) {
-      this.outputFormat = other.outputFormat;
+      this.outputFormat = org.apache.hive.common.util.HiveStringUtils.intern(other.outputFormat);
     }
     this.compressed = other.compressed;
     this.numBuckets = other.numBuckets;
@@ -256,32 +260,18 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
       this.serdeInfo = new SerDeInfo(other.serdeInfo);
     }
     if (other.isSetBucketCols()) {
-      List<String> __this__bucketCols = new ArrayList<String>();
-      for (String other_element : other.bucketCols) {
-        __this__bucketCols.add(other_element);
-      }
+      List<String> __this__bucketCols = new ArrayList<String>(other.bucketCols);
       this.bucketCols = __this__bucketCols;
     }
     if (other.isSetSortCols()) {
-      List<Order> __this__sortCols = new ArrayList<Order>();
+      List<Order> __this__sortCols = new ArrayList<Order>(other.sortCols.size());
       for (Order other_element : other.sortCols) {
         __this__sortCols.add(new Order(other_element));
       }
       this.sortCols = __this__sortCols;
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     if (other.isSetSkewedInfo()) {
@@ -356,7 +346,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   }
 
   public void setLocation(String location) {
-    this.location = location;
+    this.location = org.apache.hive.common.util.HiveStringUtils.intern(location);
   }
 
   public void unsetLocation() {
@@ -379,7 +369,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   }
 
   public void setInputFormat(String inputFormat) {
-    this.inputFormat = inputFormat;
+    this.inputFormat = org.apache.hive.common.util.HiveStringUtils.intern(inputFormat);
   }
 
   public void unsetInputFormat() {
@@ -402,7 +392,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   }
 
   public void setOutputFormat(String outputFormat) {
-    this.outputFormat = outputFormat;
+    this.outputFormat = org.apache.hive.common.util.HiveStringUtils.intern(outputFormat);
   }
 
   public void unsetOutputFormat() {
@@ -507,7 +497,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   }
 
   public void setBucketCols(List<String> bucketCols) {
-    this.bucketCols = bucketCols;
+    this.bucketCols = org.apache.hive.common.util.HiveStringUtils.intern(bucketCols);
   }
 
   public void unsetBucketCols() {
@@ -579,7 +569,7 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
   }
 
   public void setParameters(Map<String,String> parameters) {
-    this.parameters = parameters;
+    this.parameters = org.apache.hive.common.util.HiveStringUtils.intern(parameters);
   }
 
   public void unsetParameters() {
@@ -946,195 +936,195 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_cols = true && (isSetCols());
-    builder.append(present_cols);
+    list.add(present_cols);
     if (present_cols)
-      builder.append(cols);
+      list.add(cols);
 
     boolean present_location = true && (isSetLocation());
-    builder.append(present_location);
+    list.add(present_location);
     if (present_location)
-      builder.append(location);
+      list.add(location);
 
     boolean present_inputFormat = true && (isSetInputFormat());
-    builder.append(present_inputFormat);
+    list.add(present_inputFormat);
     if (present_inputFormat)
-      builder.append(inputFormat);
+      list.add(inputFormat);
 
     boolean present_outputFormat = true && (isSetOutputFormat());
-    builder.append(present_outputFormat);
+    list.add(present_outputFormat);
     if (present_outputFormat)
-      builder.append(outputFormat);
+      list.add(outputFormat);
 
     boolean present_compressed = true;
-    builder.append(present_compressed);
+    list.add(present_compressed);
     if (present_compressed)
-      builder.append(compressed);
+      list.add(compressed);
 
     boolean present_numBuckets = true;
-    builder.append(present_numBuckets);
+    list.add(present_numBuckets);
     if (present_numBuckets)
-      builder.append(numBuckets);
+      list.add(numBuckets);
 
     boolean present_serdeInfo = true && (isSetSerdeInfo());
-    builder.append(present_serdeInfo);
+    list.add(present_serdeInfo);
     if (present_serdeInfo)
-      builder.append(serdeInfo);
+      list.add(serdeInfo);
 
     boolean present_bucketCols = true && (isSetBucketCols());
-    builder.append(present_bucketCols);
+    list.add(present_bucketCols);
     if (present_bucketCols)
-      builder.append(bucketCols);
+      list.add(bucketCols);
 
     boolean present_sortCols = true && (isSetSortCols());
-    builder.append(present_sortCols);
+    list.add(present_sortCols);
     if (present_sortCols)
-      builder.append(sortCols);
+      list.add(sortCols);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_skewedInfo = true && (isSetSkewedInfo());
-    builder.append(present_skewedInfo);
+    list.add(present_skewedInfo);
     if (present_skewedInfo)
-      builder.append(skewedInfo);
+      list.add(skewedInfo);
 
     boolean present_storedAsSubDirectories = true && (isSetStoredAsSubDirectories());
-    builder.append(present_storedAsSubDirectories);
+    list.add(present_storedAsSubDirectories);
     if (present_storedAsSubDirectories)
-      builder.append(storedAsSubDirectories);
+      list.add(storedAsSubDirectories);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(StorageDescriptor other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    StorageDescriptor typedOther = (StorageDescriptor)other;
 
-    lastComparison = Boolean.valueOf(isSetCols()).compareTo(typedOther.isSetCols());
+    lastComparison = Boolean.valueOf(isSetCols()).compareTo(other.isSetCols());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCols()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.cols, typedOther.cols);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.cols, other.cols);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLocation()).compareTo(typedOther.isSetLocation());
+    lastComparison = Boolean.valueOf(isSetLocation()).compareTo(other.isSetLocation());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLocation()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.location, typedOther.location);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.location, other.location);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetInputFormat()).compareTo(typedOther.isSetInputFormat());
+    lastComparison = Boolean.valueOf(isSetInputFormat()).compareTo(other.isSetInputFormat());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetInputFormat()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.inputFormat, typedOther.inputFormat);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.inputFormat, other.inputFormat);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOutputFormat()).compareTo(typedOther.isSetOutputFormat());
+    lastComparison = Boolean.valueOf(isSetOutputFormat()).compareTo(other.isSetOutputFormat());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOutputFormat()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.outputFormat, typedOther.outputFormat);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.outputFormat, other.outputFormat);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCompressed()).compareTo(typedOther.isSetCompressed());
+    lastComparison = Boolean.valueOf(isSetCompressed()).compareTo(other.isSetCompressed());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCompressed()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.compressed, typedOther.compressed);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.compressed, other.compressed);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumBuckets()).compareTo(typedOther.isSetNumBuckets());
+    lastComparison = Boolean.valueOf(isSetNumBuckets()).compareTo(other.isSetNumBuckets());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumBuckets()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numBuckets, typedOther.numBuckets);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numBuckets, other.numBuckets);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSerdeInfo()).compareTo(typedOther.isSetSerdeInfo());
+    lastComparison = Boolean.valueOf(isSetSerdeInfo()).compareTo(other.isSetSerdeInfo());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSerdeInfo()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serdeInfo, typedOther.serdeInfo);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serdeInfo, other.serdeInfo);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetBucketCols()).compareTo(typedOther.isSetBucketCols());
+    lastComparison = Boolean.valueOf(isSetBucketCols()).compareTo(other.isSetBucketCols());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetBucketCols()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.bucketCols, typedOther.bucketCols);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.bucketCols, other.bucketCols);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSortCols()).compareTo(typedOther.isSetSortCols());
+    lastComparison = Boolean.valueOf(isSetSortCols()).compareTo(other.isSetSortCols());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSortCols()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sortCols, typedOther.sortCols);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sortCols, other.sortCols);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSkewedInfo()).compareTo(typedOther.isSetSkewedInfo());
+    lastComparison = Boolean.valueOf(isSetSkewedInfo()).compareTo(other.isSetSkewedInfo());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSkewedInfo()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedInfo, typedOther.skewedInfo);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.skewedInfo, other.skewedInfo);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStoredAsSubDirectories()).compareTo(typedOther.isSetStoredAsSubDirectories());
+    lastComparison = Boolean.valueOf(isSetStoredAsSubDirectories()).compareTo(other.isSetStoredAsSubDirectories());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStoredAsSubDirectories()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.storedAsSubDirectories, typedOther.storedAsSubDirectories);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.storedAsSubDirectories, other.storedAsSubDirectories);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -1302,12 +1292,12 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
               {
                 org.apache.thrift.protocol.TList _list156 = iprot.readListBegin();
                 struct.cols = new ArrayList<FieldSchema>(_list156.size);
-                for (int _i157 = 0; _i157 < _list156.size; ++_i157)
+                FieldSchema _elem157;
+                for (int _i158 = 0; _i158 < _list156.size; ++_i158)
                 {
-                  FieldSchema _elem158; // optional
-                  _elem158 = new FieldSchema();
-                  _elem158.read(iprot);
-                  struct.cols.add(_elem158);
+                  _elem157 = new FieldSchema();
+                  _elem157.read(iprot);
+                  struct.cols.add(_elem157);
                 }
                 iprot.readListEnd();
               }
@@ -1370,11 +1360,11 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
               {
                 org.apache.thrift.protocol.TList _list159 = iprot.readListBegin();
                 struct.bucketCols = new ArrayList<String>(_list159.size);
-                for (int _i160 = 0; _i160 < _list159.size; ++_i160)
+                String _elem160;
+                for (int _i161 = 0; _i161 < _list159.size; ++_i161)
                 {
-                  String _elem161; // optional
-                  _elem161 = iprot.readString();
-                  struct.bucketCols.add(_elem161);
+                  _elem160 = iprot.readString();
+                  struct.bucketCols.add(_elem160);
                 }
                 iprot.readListEnd();
               }
@@ -1388,12 +1378,12 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
               {
                 org.apache.thrift.protocol.TList _list162 = iprot.readListBegin();
                 struct.sortCols = new ArrayList<Order>(_list162.size);
-                for (int _i163 = 0; _i163 < _list162.size; ++_i163)
+                Order _elem163;
+                for (int _i164 = 0; _i164 < _list162.size; ++_i164)
                 {
-                  Order _elem164; // optional
-                  _elem164 = new Order();
-                  _elem164.read(iprot);
-                  struct.sortCols.add(_elem164);
+                  _elem163 = new Order();
+                  _elem163.read(iprot);
+                  struct.sortCols.add(_elem163);
                 }
                 iprot.readListEnd();
               }
@@ -1407,13 +1397,13 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
               {
                 org.apache.thrift.protocol.TMap _map165 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map165.size);
-                for (int _i166 = 0; _i166 < _map165.size; ++_i166)
+                String _key166;
+                String _val167;
+                for (int _i168 = 0; _i168 < _map165.size; ++_i168)
                 {
-                  String _key167; // required
-                  String _val168; // required
-                  _key167 = iprot.readString();
-                  _val168 = iprot.readString();
-                  struct.parameters.put(_key167, _val168);
+                  _key166 = iprot.readString();
+                  _val167 = iprot.readString();
+                  struct.parameters.put(_key166, _val167);
                 }
                 iprot.readMapEnd();
               }
@@ -1665,12 +1655,12 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
         {
           org.apache.thrift.protocol.TList _list177 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.cols = new ArrayList<FieldSchema>(_list177.size);
-          for (int _i178 = 0; _i178 < _list177.size; ++_i178)
+          FieldSchema _elem178;
+          for (int _i179 = 0; _i179 < _list177.size; ++_i179)
           {
-            FieldSchema _elem179; // optional
-            _elem179 = new FieldSchema();
-            _elem179.read(iprot);
-            struct.cols.add(_elem179);
+            _elem178 = new FieldSchema();
+            _elem178.read(iprot);
+            struct.cols.add(_elem178);
           }
         }
         struct.setColsIsSet(true);
@@ -1704,11 +1694,11 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
         {
           org.apache.thrift.protocol.TList _list180 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.bucketCols = new ArrayList<String>(_list180.size);
-          for (int _i181 = 0; _i181 < _list180.size; ++_i181)
+          String _elem181;
+          for (int _i182 = 0; _i182 < _list180.size; ++_i182)
           {
-            String _elem182; // optional
-            _elem182 = iprot.readString();
-            struct.bucketCols.add(_elem182);
+            _elem181 = iprot.readString();
+            struct.bucketCols.add(_elem181);
           }
         }
         struct.setBucketColsIsSet(true);
@@ -1717,12 +1707,12 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
         {
           org.apache.thrift.protocol.TList _list183 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.sortCols = new ArrayList<Order>(_list183.size);
-          for (int _i184 = 0; _i184 < _list183.size; ++_i184)
+          Order _elem184;
+          for (int _i185 = 0; _i185 < _list183.size; ++_i185)
           {
-            Order _elem185; // optional
-            _elem185 = new Order();
-            _elem185.read(iprot);
-            struct.sortCols.add(_elem185);
+            _elem184 = new Order();
+            _elem184.read(iprot);
+            struct.sortCols.add(_elem184);
           }
         }
         struct.setSortColsIsSet(true);
@@ -1731,13 +1721,13 @@ public class StorageDescriptor implements org.apache.thrift.TBase<StorageDescrip
         {
           org.apache.thrift.protocol.TMap _map186 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map186.size);
-          for (int _i187 = 0; _i187 < _map186.size; ++_i187)
+          String _key187;
+          String _val188;
+          for (int _i189 = 0; _i189 < _map186.size; ++_i189)
           {
-            String _key188; // required
-            String _val189; // required
-            _key188 = iprot.readString();
-            _val189 = iprot.readString();
-            struct.parameters.put(_key188, _val189);
+            _key187 = iprot.readString();
+            _val188 = iprot.readString();
+            struct.parameters.put(_key187, _val188);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StringColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StringColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StringColumnStatsData.java
index db3274a..6409c6b 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StringColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/StringColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class StringColumnStatsData implements org.apache.thrift.TBase<StringColumnStatsData, StringColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class StringColumnStatsData implements org.apache.thrift.TBase<StringColumnStatsData, StringColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<StringColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("StringColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField MAX_COL_LEN_FIELD_DESC = new org.apache.thrift.protocol.TField("maxColLen", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -401,75 +405,75 @@ public class StringColumnStatsData implements org.apache.thrift.TBase<StringColu
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_maxColLen = true;
-    builder.append(present_maxColLen);
+    list.add(present_maxColLen);
     if (present_maxColLen)
-      builder.append(maxColLen);
+      list.add(maxColLen);
 
     boolean present_avgColLen = true;
-    builder.append(present_avgColLen);
+    list.add(present_avgColLen);
     if (present_avgColLen)
-      builder.append(avgColLen);
+      list.add(avgColLen);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
     boolean present_numDVs = true;
-    builder.append(present_numDVs);
+    list.add(present_numDVs);
     if (present_numDVs)
-      builder.append(numDVs);
+      list.add(numDVs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(StringColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    StringColumnStatsData typedOther = (StringColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetMaxColLen()).compareTo(typedOther.isSetMaxColLen());
+    lastComparison = Boolean.valueOf(isSetMaxColLen()).compareTo(other.isSetMaxColLen());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxColLen()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxColLen, typedOther.maxColLen);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxColLen, other.maxColLen);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAvgColLen()).compareTo(typedOther.isSetAvgColLen());
+    lastComparison = Boolean.valueOf(isSetAvgColLen()).compareTo(other.isSetAvgColLen());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAvgColLen()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.avgColLen, typedOther.avgColLen);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.avgColLen, other.avgColLen);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(typedOther.isSetNumDVs());
+    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(other.isSetNumDVs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumDVs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, typedOther.numDVs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, other.numDVs);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Table.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Table.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Table.java
index 484bd6a..55f7dfd 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Table.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Table.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, java.io.Serializable, Cloneable, Comparable<Table> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Table");
 
   private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -173,7 +177,7 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
   private static final int __RETENTION_ISSET_ID = 2;
   private static final int __TEMPORARY_ISSET_ID = 3;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PRIVILEGES,_Fields.TEMPORARY};
+  private static final _Fields optionals[] = {_Fields.PRIVILEGES,_Fields.TEMPORARY};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -270,25 +274,14 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
       this.sd = new StorageDescriptor(other.sd);
     }
     if (other.isSetPartitionKeys()) {
-      List<FieldSchema> __this__partitionKeys = new ArrayList<FieldSchema>();
+      List<FieldSchema> __this__partitionKeys = new ArrayList<FieldSchema>(other.partitionKeys.size());
       for (FieldSchema other_element : other.partitionKeys) {
         __this__partitionKeys.add(new FieldSchema(other_element));
       }
       this.partitionKeys = __this__partitionKeys;
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     if (other.isSetViewOriginalText()) {
@@ -1024,225 +1017,225 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_owner = true && (isSetOwner());
-    builder.append(present_owner);
+    list.add(present_owner);
     if (present_owner)
-      builder.append(owner);
+      list.add(owner);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_lastAccessTime = true;
-    builder.append(present_lastAccessTime);
+    list.add(present_lastAccessTime);
     if (present_lastAccessTime)
-      builder.append(lastAccessTime);
+      list.add(lastAccessTime);
 
     boolean present_retention = true;
-    builder.append(present_retention);
+    list.add(present_retention);
     if (present_retention)
-      builder.append(retention);
+      list.add(retention);
 
     boolean present_sd = true && (isSetSd());
-    builder.append(present_sd);
+    list.add(present_sd);
     if (present_sd)
-      builder.append(sd);
+      list.add(sd);
 
     boolean present_partitionKeys = true && (isSetPartitionKeys());
-    builder.append(present_partitionKeys);
+    list.add(present_partitionKeys);
     if (present_partitionKeys)
-      builder.append(partitionKeys);
+      list.add(partitionKeys);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_viewOriginalText = true && (isSetViewOriginalText());
-    builder.append(present_viewOriginalText);
+    list.add(present_viewOriginalText);
     if (present_viewOriginalText)
-      builder.append(viewOriginalText);
+      list.add(viewOriginalText);
 
     boolean present_viewExpandedText = true && (isSetViewExpandedText());
-    builder.append(present_viewExpandedText);
+    list.add(present_viewExpandedText);
     if (present_viewExpandedText)
-      builder.append(viewExpandedText);
+      list.add(viewExpandedText);
 
     boolean present_tableType = true && (isSetTableType());
-    builder.append(present_tableType);
+    list.add(present_tableType);
     if (present_tableType)
-      builder.append(tableType);
+      list.add(tableType);
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
     boolean present_temporary = true && (isSetTemporary());
-    builder.append(present_temporary);
+    list.add(present_temporary);
     if (present_temporary)
-      builder.append(temporary);
+      list.add(temporary);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Table other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Table typedOther = (Table)other;
 
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwner()).compareTo(typedOther.isSetOwner());
+    lastComparison = Boolean.valueOf(isSetOwner()).compareTo(other.isSetOwner());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwner()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.owner, typedOther.owner);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.owner, other.owner);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(typedOther.isSetLastAccessTime());
+    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(other.isSetLastAccessTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastAccessTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, typedOther.lastAccessTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, other.lastAccessTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRetention()).compareTo(typedOther.isSetRetention());
+    lastComparison = Boolean.valueOf(isSetRetention()).compareTo(other.isSetRetention());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRetention()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.retention, typedOther.retention);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.retention, other.retention);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSd()).compareTo(typedOther.isSetSd());
+    lastComparison = Boolean.valueOf(isSetSd()).compareTo(other.isSetSd());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSd()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, typedOther.sd);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, other.sd);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionKeys()).compareTo(typedOther.isSetPartitionKeys());
+    lastComparison = Boolean.valueOf(isSetPartitionKeys()).compareTo(other.isSetPartitionKeys());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionKeys()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionKeys, typedOther.partitionKeys);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionKeys, other.partitionKeys);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetViewOriginalText()).compareTo(typedOther.isSetViewOriginalText());
+    lastComparison = Boolean.valueOf(isSetViewOriginalText()).compareTo(other.isSetViewOriginalText());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetViewOriginalText()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.viewOriginalText, typedOther.viewOriginalText);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.viewOriginalText, other.viewOriginalText);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetViewExpandedText()).compareTo(typedOther.isSetViewExpandedText());
+    lastComparison = Boolean.valueOf(isSetViewExpandedText()).compareTo(other.isSetViewExpandedText());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetViewExpandedText()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.viewExpandedText, typedOther.viewExpandedText);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.viewExpandedText, other.viewExpandedText);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableType()).compareTo(typedOther.isSetTableType());
+    lastComparison = Boolean.valueOf(isSetTableType()).compareTo(other.isSetTableType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableType, typedOther.tableType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableType, other.tableType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTemporary()).compareTo(typedOther.isSetTemporary());
+    lastComparison = Boolean.valueOf(isSetTemporary()).compareTo(other.isSetTemporary());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTemporary()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.temporary, typedOther.temporary);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.temporary, other.temporary);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -1479,12 +1472,12 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
               {
                 org.apache.thrift.protocol.TList _list190 = iprot.readListBegin();
                 struct.partitionKeys = new ArrayList<FieldSchema>(_list190.size);
-                for (int _i191 = 0; _i191 < _list190.size; ++_i191)
+                FieldSchema _elem191;
+                for (int _i192 = 0; _i192 < _list190.size; ++_i192)
                 {
-                  FieldSchema _elem192; // optional
-                  _elem192 = new FieldSchema();
-                  _elem192.read(iprot);
-                  struct.partitionKeys.add(_elem192);
+                  _elem191 = new FieldSchema();
+                  _elem191.read(iprot);
+                  struct.partitionKeys.add(_elem191);
                 }
                 iprot.readListEnd();
               }
@@ -1498,13 +1491,13 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map193 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map193.size);
-                for (int _i194 = 0; _i194 < _map193.size; ++_i194)
+                String _key194;
+                String _val195;
+                for (int _i196 = 0; _i196 < _map193.size; ++_i196)
                 {
-                  String _key195; // required
-                  String _val196; // required
-                  _key195 = iprot.readString();
-                  _val196 = iprot.readString();
-                  struct.parameters.put(_key195, _val196);
+                  _key194 = iprot.readString();
+                  _val195 = iprot.readString();
+                  struct.parameters.put(_key194, _val195);
                 }
                 iprot.readMapEnd();
               }
@@ -1803,12 +1796,12 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
         {
           org.apache.thrift.protocol.TList _list201 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.partitionKeys = new ArrayList<FieldSchema>(_list201.size);
-          for (int _i202 = 0; _i202 < _list201.size; ++_i202)
+          FieldSchema _elem202;
+          for (int _i203 = 0; _i203 < _list201.size; ++_i203)
           {
-            FieldSchema _elem203; // optional
-            _elem203 = new FieldSchema();
-            _elem203.read(iprot);
-            struct.partitionKeys.add(_elem203);
+            _elem202 = new FieldSchema();
+            _elem202.read(iprot);
+            struct.partitionKeys.add(_elem202);
           }
         }
         struct.setPartitionKeysIsSet(true);
@@ -1817,13 +1810,13 @@ public class Table implements org.apache.thrift.TBase<Table, Table._Fields>, jav
         {
           org.apache.thrift.protocol.TMap _map204 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map204.size);
-          for (int _i205 = 0; _i205 < _map204.size; ++_i205)
+          String _key205;
+          String _val206;
+          for (int _i207 = 0; _i207 < _map204.size; ++_i207)
           {
-            String _key206; // required
-            String _val207; // required
-            _key206 = iprot.readString();
-            _val207 = iprot.readString();
-            struct.parameters.put(_key206, _val207);
+            _key205 = iprot.readString();
+            _val206 = iprot.readString();
+            struct.parameters.put(_key205, _val206);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsRequest.java
index 2073829..1faa547 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequest, TableStatsRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequest, TableStatsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<TableStatsRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableStatsRequest");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -152,10 +156,7 @@ public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequ
       this.tblName = other.tblName;
     }
     if (other.isSetColNames()) {
-      List<String> __this__colNames = new ArrayList<String>();
-      for (String other_element : other.colNames) {
-        __this__colNames.add(other_element);
-      }
+      List<String> __this__colNames = new ArrayList<String>(other.colNames);
       this.colNames = __this__colNames;
     }
   }
@@ -361,60 +362,60 @@ public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequ
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tblName = true && (isSetTblName());
-    builder.append(present_tblName);
+    list.add(present_tblName);
     if (present_tblName)
-      builder.append(tblName);
+      list.add(tblName);
 
     boolean present_colNames = true && (isSetColNames());
-    builder.append(present_colNames);
+    list.add(present_colNames);
     if (present_colNames)
-      builder.append(colNames);
+      list.add(colNames);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TableStatsRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TableStatsRequest typedOther = (TableStatsRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(typedOther.isSetTblName());
+    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(other.isSetTblName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTblName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, typedOther.tblName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, other.tblName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColNames()).compareTo(typedOther.isSetColNames());
+    lastComparison = Boolean.valueOf(isSetColNames()).compareTo(other.isSetColNames());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColNames()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colNames, typedOther.colNames);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colNames, other.colNames);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -538,11 +539,11 @@ public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequ
               {
                 org.apache.thrift.protocol.TList _list356 = iprot.readListBegin();
                 struct.colNames = new ArrayList<String>(_list356.size);
-                for (int _i357 = 0; _i357 < _list356.size; ++_i357)
+                String _elem357;
+                for (int _i358 = 0; _i358 < _list356.size; ++_i358)
                 {
-                  String _elem358; // optional
-                  _elem358 = iprot.readString();
-                  struct.colNames.add(_elem358);
+                  _elem357 = iprot.readString();
+                  struct.colNames.add(_elem357);
                 }
                 iprot.readListEnd();
               }
@@ -624,11 +625,11 @@ public class TableStatsRequest implements org.apache.thrift.TBase<TableStatsRequ
       {
         org.apache.thrift.protocol.TList _list361 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.colNames = new ArrayList<String>(_list361.size);
-        for (int _i362 = 0; _i362 < _list361.size; ++_i362)
+        String _elem362;
+        for (int _i363 = 0; _i363 < _list361.size; ++_i363)
         {
-          String _elem363; // optional
-          _elem363 = iprot.readString();
-          struct.colNames.add(_elem363);
+          _elem362 = iprot.readString();
+          struct.colNames.add(_elem362);
         }
       }
       struct.setColNamesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsResult.java
index 541370f..535d2ff 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsResult.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TableStatsResult.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResult, TableStatsResult._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResult, TableStatsResult._Fields>, java.io.Serializable, Cloneable, Comparable<TableStatsResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TableStatsResult");
 
   private static final org.apache.thrift.protocol.TField TABLE_STATS_FIELD_DESC = new org.apache.thrift.protocol.TField("tableStats", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResul
    */
   public TableStatsResult(TableStatsResult other) {
     if (other.isSetTableStats()) {
-      List<ColumnStatisticsObj> __this__tableStats = new ArrayList<ColumnStatisticsObj>();
+      List<ColumnStatisticsObj> __this__tableStats = new ArrayList<ColumnStatisticsObj>(other.tableStats.size());
       for (ColumnStatisticsObj other_element : other.tableStats) {
         __this__tableStats.add(new ColumnStatisticsObj(other_element));
       }
@@ -245,30 +249,30 @@ public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResul
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_tableStats = true && (isSetTableStats());
-    builder.append(present_tableStats);
+    list.add(present_tableStats);
     if (present_tableStats)
-      builder.append(tableStats);
+      list.add(tableStats);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TableStatsResult other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TableStatsResult typedOther = (TableStatsResult)other;
 
-    lastComparison = Boolean.valueOf(isSetTableStats()).compareTo(typedOther.isSetTableStats());
+    lastComparison = Boolean.valueOf(isSetTableStats()).compareTo(other.isSetTableStats());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableStats()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableStats, typedOther.tableStats);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableStats, other.tableStats);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResul
               {
                 org.apache.thrift.protocol.TList _list330 = iprot.readListBegin();
                 struct.tableStats = new ArrayList<ColumnStatisticsObj>(_list330.size);
-                for (int _i331 = 0; _i331 < _list330.size; ++_i331)
+                ColumnStatisticsObj _elem331;
+                for (int _i332 = 0; _i332 < _list330.size; ++_i332)
                 {
-                  ColumnStatisticsObj _elem332; // optional
-                  _elem332 = new ColumnStatisticsObj();
-                  _elem332.read(iprot);
-                  struct.tableStats.add(_elem332);
+                  _elem331 = new ColumnStatisticsObj();
+                  _elem331.read(iprot);
+                  struct.tableStats.add(_elem331);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class TableStatsResult implements org.apache.thrift.TBase<TableStatsResul
       {
         org.apache.thrift.protocol.TList _list335 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.tableStats = new ArrayList<ColumnStatisticsObj>(_list335.size);
-        for (int _i336 = 0; _i336 < _list335.size; ++_i336)
+        ColumnStatisticsObj _elem336;
+        for (int _i337 = 0; _i337 < _list335.size; ++_i337)
         {
-          ColumnStatisticsObj _elem337; // optional
-          _elem337 = new ColumnStatisticsObj();
-          _elem337.read(iprot);
-          struct.tableStats.add(_elem337);
+          _elem336 = new ColumnStatisticsObj();
+          _elem336.read(iprot);
+          struct.tableStats.add(_elem336);
         }
       }
       struct.setTableStatsIsSet(true);


[33/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
index 5fc965b..cc99079 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,12 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
 public class ThriftHiveMetastore {
 
   /**
@@ -288,251 +292,251 @@ public class ThriftHiveMetastore {
 
   public interface AsyncIface extends com.facebook.fb303.FacebookService .AsyncIface {
 
-    public void getMetaConf(String key, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getMetaConf_call> resultHandler) throws org.apache.thrift.TException;
+    public void getMetaConf(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void setMetaConf(String key, String value, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.setMetaConf_call> resultHandler) throws org.apache.thrift.TException;
+    public void setMetaConf(String key, String value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_database(Database database, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_database_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_database(Database database, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_database(String name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_database_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_database(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_database(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_database_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_database(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_databases(String pattern, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_databases_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_databases(String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_all_databases(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_all_databases_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_all_databases(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_database(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_database_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_database(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_type(String name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_type_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_type(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_type(Type type, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_type_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_type(Type type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_type(String type, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_type_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_type(String type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_type_all(String name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_type_all_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_type_all(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_fields(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_fields_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_fields(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_fields_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_fields_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_fields_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_schema(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_schema_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_schema(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_schema_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_schema_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_schema_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_table(Table tbl, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_table_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_table(Table tbl, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_table_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_table(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_table_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_table(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_table_with_environment_context(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_table_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_table_with_environment_context(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_tables(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_tables_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_tables(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_all_tables(String db_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_all_tables_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_all_tables(String db_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_table(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_table_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_table(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_table_objects_by_name(String dbname, List<String> tbl_names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_table_objects_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_table_objects_by_name(String dbname, List<String> tbl_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_table_names_by_filter(String dbname, String filter, short max_tables, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_table_names_by_filter_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_table_names_by_filter(String dbname, String filter, short max_tables, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_table(String dbname, String tbl_name, Table new_tbl, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_table_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_table(String dbname, String tbl_name, Table new_tbl, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_table_with_environment_context(String dbname, String tbl_name, Table new_tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_table_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_table_with_environment_context(String dbname, String tbl_name, Table new_tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_table_with_cascade(String dbname, String tbl_name, Table new_tbl, boolean cascade, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_table_with_cascade_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_table_with_cascade(String dbname, String tbl_name, Table new_tbl, boolean cascade, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_partition(Partition new_part, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_partition(Partition new_part, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_partition_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_partitions(List<Partition> new_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_partitions_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_partitions(List<Partition> new_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_partitions_pspec(List<PartitionSpec> new_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_partitions_pspec_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_partitions_pspec(List<PartitionSpec> new_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void append_partition(String db_name, String tbl_name, List<String> part_vals, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.append_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void append_partition(String db_name, String tbl_name, List<String> part_vals, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_partitions_req(AddPartitionsRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_partitions_req_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_partitions_req(AddPartitionsRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void append_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.append_partition_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void append_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void append_partition_by_name(String db_name, String tbl_name, String part_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.append_partition_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void append_partition_by_name(String db_name, String tbl_name, String part_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void append_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.append_partition_by_name_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void append_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_partition(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_partition(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_partition_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_partition_with_environment_context(String db_name, String tbl_name, List<String> part_vals, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_partition_by_name(String db_name, String tbl_name, String part_name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_partition_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_partition_by_name(String db_name, String tbl_name, String part_name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_partition_by_name_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_partition_by_name_with_environment_context(String db_name, String tbl_name, String part_name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_partitions_req(DropPartitionsRequest req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_partitions_req_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_partitions_req(DropPartitionsRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition(String db_name, String tbl_name, List<String> part_vals, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition(String db_name, String tbl_name, List<String> part_vals, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void exchange_partition(Map<String,String> partitionSpecs, String source_db, String source_table_name, String dest_db, String dest_table_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.exchange_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void exchange_partition(Map<String,String> partitionSpecs, String source_db, String source_table_name, String dest_db, String dest_table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition_with_auth(String db_name, String tbl_name, List<String> part_vals, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_with_auth_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition_with_auth(String db_name, String tbl_name, List<String> part_vals, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition_by_name(String db_name, String tbl_name, String part_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition_by_name(String db_name, String tbl_name, String part_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions(String db_name, String tbl_name, short max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions(String db_name, String tbl_name, short max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_with_auth(String db_name, String tbl_name, short max_parts, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_with_auth_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_with_auth(String db_name, String tbl_name, short max_parts, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_pspec(String db_name, String tbl_name, int max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_pspec_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_pspec(String db_name, String tbl_name, int max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition_names(String db_name, String tbl_name, short max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_names_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition_names(String db_name, String tbl_name, short max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_ps_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void 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, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_ps_with_auth_call> resultHandler) throws org.apache.thrift.TException;
+    public void 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, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition_names_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_names_ps_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition_names_ps(String db_name, String tbl_name, List<String> part_vals, short max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_by_filter(String db_name, String tbl_name, String filter, short max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_by_filter_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_by_filter(String db_name, String tbl_name, String filter, short max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_part_specs_by_filter(String db_name, String tbl_name, String filter, int max_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_part_specs_by_filter_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_part_specs_by_filter(String db_name, String tbl_name, String filter, int max_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_by_expr(PartitionsByExprRequest req, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_by_expr_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_by_expr(PartitionsByExprRequest req, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_by_names(String db_name, String tbl_name, List<String> names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_by_names_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_by_names(String db_name, String tbl_name, List<String> names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_partition(String db_name, String tbl_name, Partition new_part, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_partition(String db_name, String tbl_name, Partition new_part, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_partitions(String db_name, String tbl_name, List<Partition> new_parts, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_partitions_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_partitions(String db_name, String tbl_name, List<Partition> new_parts, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_partition_with_environment_context(String db_name, String tbl_name, Partition new_part, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_partition_with_environment_context_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_partition_with_environment_context(String db_name, String tbl_name, Partition new_part, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void rename_partition(String db_name, String tbl_name, List<String> part_vals, Partition new_part, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.rename_partition_call> resultHandler) throws org.apache.thrift.TException;
+    public void rename_partition(String db_name, String tbl_name, List<String> part_vals, Partition new_part, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void partition_name_has_valid_characters(List<String> part_vals, boolean throw_exception, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.partition_name_has_valid_characters_call> resultHandler) throws org.apache.thrift.TException;
+    public void partition_name_has_valid_characters(List<String> part_vals, boolean throw_exception, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_config_value(String name, String defaultValue, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_config_value_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_config_value(String name, String defaultValue, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void partition_name_to_vals(String part_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.partition_name_to_vals_call> resultHandler) throws org.apache.thrift.TException;
+    public void partition_name_to_vals(String part_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void partition_name_to_spec(String part_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.partition_name_to_spec_call> resultHandler) throws org.apache.thrift.TException;
+    public void partition_name_to_spec(String part_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void markPartitionForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.markPartitionForEvent_call> resultHandler) throws org.apache.thrift.TException;
+    public void markPartitionForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void isPartitionMarkedForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.isPartitionMarkedForEvent_call> resultHandler) throws org.apache.thrift.TException;
+    public void isPartitionMarkedForEvent(String db_name, String tbl_name, Map<String,String> part_vals, PartitionEventType eventType, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_index(Index new_index, Table index_table, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_index_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_index(Index new_index, Table index_table, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_index(String dbname, String base_tbl_name, String idx_name, Index new_idx, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_index_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_index(String dbname, String base_tbl_name, String idx_name, Index new_idx, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_index_by_name(String db_name, String tbl_name, String index_name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_index_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_index_by_name(String db_name, String tbl_name, String index_name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_index_by_name(String db_name, String tbl_name, String index_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_index_by_name_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_index_by_name(String db_name, String tbl_name, String index_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_indexes(String db_name, String tbl_name, short max_indexes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_indexes_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_indexes(String db_name, String tbl_name, short max_indexes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_index_names(String db_name, String tbl_name, short max_indexes, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_index_names_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_index_names(String db_name, String tbl_name, short max_indexes, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void update_table_column_statistics(ColumnStatistics stats_obj, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.update_table_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void update_table_column_statistics(ColumnStatistics stats_obj, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void update_partition_column_statistics(ColumnStatistics stats_obj, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.update_partition_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void update_partition_column_statistics(ColumnStatistics stats_obj, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_table_column_statistics(String db_name, String tbl_name, String col_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_table_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_table_column_statistics(String db_name, String tbl_name, String col_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partition_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_table_statistics_req(TableStatsRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_table_statistics_req_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_table_statistics_req(TableStatsRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_partitions_statistics_req(PartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_partitions_statistics_req_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_partitions_statistics_req(PartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_aggr_stats_for(PartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_aggr_stats_for_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_aggr_stats_for(PartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void set_aggr_stats_for(SetPartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.set_aggr_stats_for_call> resultHandler) throws org.apache.thrift.TException;
+    public void set_aggr_stats_for(SetPartitionsStatsRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void delete_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.delete_partition_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void delete_partition_column_statistics(String db_name, String tbl_name, String part_name, String col_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void delete_table_column_statistics(String db_name, String tbl_name, String col_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.delete_table_column_statistics_call> resultHandler) throws org.apache.thrift.TException;
+    public void delete_table_column_statistics(String db_name, String tbl_name, String col_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_function(Function func, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_function_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_function(Function func, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_function(String dbName, String funcName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_function_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_function(String dbName, String funcName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void alter_function(String dbName, String funcName, Function newFunc, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.alter_function_call> resultHandler) throws org.apache.thrift.TException;
+    public void alter_function(String dbName, String funcName, Function newFunc, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_functions(String dbName, String pattern, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_functions_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_functions(String dbName, String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_function(String dbName, String funcName, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_function_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_function(String dbName, String funcName, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void create_role(Role role, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.create_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void create_role(Role role, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void drop_role(String role_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.drop_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void drop_role(String role_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_role_names(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_role_names_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_role_names(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void grant_role(String role_name, String principal_name, PrincipalType principal_type, String grantor, PrincipalType grantorType, boolean grant_option, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.grant_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void grant_role(String role_name, String principal_name, PrincipalType principal_type, String grantor, PrincipalType grantorType, boolean grant_option, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void revoke_role(String role_name, String principal_name, PrincipalType principal_type, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.revoke_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void revoke_role(String role_name, String principal_name, PrincipalType principal_type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void list_roles(String principal_name, PrincipalType principal_type, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.list_roles_call> resultHandler) throws org.apache.thrift.TException;
+    public void list_roles(String principal_name, PrincipalType principal_type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void grant_revoke_role(GrantRevokeRoleRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.grant_revoke_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void grant_revoke_role(GrantRevokeRoleRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_principals_in_role(GetPrincipalsInRoleRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_principals_in_role_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_principals_in_role(GetPrincipalsInRoleRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_role_grants_for_principal_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_privilege_set(HiveObjectRef hiveObject, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_privilege_set_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_privilege_set(HiveObjectRef hiveObject, String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void list_privileges(String principal_name, PrincipalType principal_type, HiveObjectRef hiveObject, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.list_privileges_call> resultHandler) throws org.apache.thrift.TException;
+    public void list_privileges(String principal_name, PrincipalType principal_type, HiveObjectRef hiveObject, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void grant_privileges(PrivilegeBag privileges, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.grant_privileges_call> resultHandler) throws org.apache.thrift.TException;
+    public void grant_privileges(PrivilegeBag privileges, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void revoke_privileges(PrivilegeBag privileges, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.revoke_privileges_call> resultHandler) throws org.apache.thrift.TException;
+    public void revoke_privileges(PrivilegeBag privileges, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void grant_revoke_privileges(GrantRevokePrivilegeRequest request, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.grant_revoke_privileges_call> resultHandler) throws org.apache.thrift.TException;
+    public void grant_revoke_privileges(GrantRevokePrivilegeRequest request, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void set_ugi(String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.set_ugi_call> resultHandler) throws org.apache.thrift.TException;
+    public void set_ugi(String user_name, List<String> group_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_delegation_token(String token_owner, String renewer_kerberos_principal_name, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_delegation_token_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_delegation_token(String token_owner, String renewer_kerberos_principal_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void renew_delegation_token(String token_str_form, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.renew_delegation_token_call> resultHandler) throws org.apache.thrift.TException;
+    public void renew_delegation_token(String token_str_form, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void cancel_delegation_token(String token_str_form, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.cancel_delegation_token_call> resultHandler) throws org.apache.thrift.TException;
+    public void cancel_delegation_token(String token_str_form, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_open_txns(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_open_txns_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_open_txns(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_open_txns_info(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_open_txns_info_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_open_txns_info(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void open_txns(OpenTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.open_txns_call> resultHandler) throws org.apache.thrift.TException;
+    public void open_txns(OpenTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void abort_txn(AbortTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.abort_txn_call> resultHandler) throws org.apache.thrift.TException;
+    public void abort_txn(AbortTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void commit_txn(CommitTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.commit_txn_call> resultHandler) throws org.apache.thrift.TException;
+    public void commit_txn(CommitTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void lock(LockRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.lock_call> resultHandler) throws org.apache.thrift.TException;
+    public void lock(LockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void check_lock(CheckLockRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.check_lock_call> resultHandler) throws org.apache.thrift.TException;
+    public void check_lock(CheckLockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void unlock(UnlockRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.unlock_call> resultHandler) throws org.apache.thrift.TException;
+    public void unlock(UnlockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void show_locks(ShowLocksRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.show_locks_call> resultHandler) throws org.apache.thrift.TException;
+    public void show_locks(ShowLocksRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void heartbeat(HeartbeatRequest ids, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.heartbeat_call> resultHandler) throws org.apache.thrift.TException;
+    public void heartbeat(HeartbeatRequest ids, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void heartbeat_txn_range(HeartbeatTxnRangeRequest txns, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.heartbeat_txn_range_call> resultHandler) throws org.apache.thrift.TException;
+    public void heartbeat_txn_range(HeartbeatTxnRangeRequest txns, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void compact(CompactionRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.compact_call> resultHandler) throws org.apache.thrift.TException;
+    public void compact(CompactionRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void show_compact(ShowCompactRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.show_compact_call> resultHandler) throws org.apache.thrift.TException;
+    public void show_compact(ShowCompactRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void add_dynamic_partitions(AddDynamicPartitions rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.add_dynamic_partitions_call> resultHandler) throws org.apache.thrift.TException;
+    public void add_dynamic_partitions(AddDynamicPartitions rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_next_notification(NotificationEventRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_next_notification_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_next_notification(NotificationEventRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void get_current_notificationEventId(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.get_current_notificationEventId_call> resultHandler) throws org.apache.thrift.TException;
+    public void get_current_notificationEventId(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void fire_listener_event(FireEventRequest rqst, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.fire_listener_event_call> resultHandler) throws org.apache.thrift.TException;
+    public void fire_listener_event(FireEventRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
   }
 
@@ -4204,7 +4208,7 @@ public class ThriftHiveMetastore {
       super(protocolFactory, clientManager, transport);
     }
 
-    public void getMetaConf(String key, org.apache.thrift.async.AsyncMethodCallback<getMetaConf_call> resultHandler) throws org.apache.thrift.TException {
+    public void getMetaConf(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       getMetaConf_call method_call = new getMetaConf_call(key, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4213,7 +4217,7 @@ public class ThriftHiveMetastore {
 
     public static class getMetaConf_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String key;
-      public getMetaConf_call(String key, org.apache.thrift.async.AsyncMethodCallback<getMetaConf_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public getMetaConf_call(String key, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.key = key;
       }
@@ -4236,7 +4240,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void setMetaConf(String key, String value, org.apache.thrift.async.AsyncMethodCallback<setMetaConf_call> resultHandler) throws org.apache.thrift.TException {
+    public void setMetaConf(String key, String value, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       setMetaConf_call method_call = new setMetaConf_call(key, value, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4246,7 +4250,7 @@ public class ThriftHiveMetastore {
     public static class setMetaConf_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String key;
       private String value;
-      public setMetaConf_call(String key, String value, org.apache.thrift.async.AsyncMethodCallback<setMetaConf_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public setMetaConf_call(String key, String value, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.key = key;
         this.value = value;
@@ -4271,7 +4275,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void create_database(Database database, org.apache.thrift.async.AsyncMethodCallback<create_database_call> resultHandler) throws org.apache.thrift.TException {
+    public void create_database(Database database, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       create_database_call method_call = new create_database_call(database, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4280,7 +4284,7 @@ public class ThriftHiveMetastore {
 
     public static class create_database_call extends org.apache.thrift.async.TAsyncMethodCall {
       private Database database;
-      public create_database_call(Database database, org.apache.thrift.async.AsyncMethodCallback<create_database_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public create_database_call(Database database, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.database = database;
       }
@@ -4303,7 +4307,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_database(String name, org.apache.thrift.async.AsyncMethodCallback<get_database_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_database(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_database_call method_call = new get_database_call(name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4312,7 +4316,7 @@ public class ThriftHiveMetastore {
 
     public static class get_database_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String name;
-      public get_database_call(String name, org.apache.thrift.async.AsyncMethodCallback<get_database_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_database_call(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.name = name;
       }
@@ -4335,7 +4339,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void drop_database(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback<drop_database_call> resultHandler) throws org.apache.thrift.TException {
+    public void drop_database(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       drop_database_call method_call = new drop_database_call(name, deleteData, cascade, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4346,7 +4350,7 @@ public class ThriftHiveMetastore {
       private String name;
       private boolean deleteData;
       private boolean cascade;
-      public drop_database_call(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback<drop_database_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public drop_database_call(String name, boolean deleteData, boolean cascade, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.name = name;
         this.deleteData = deleteData;
@@ -4373,7 +4377,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_databases(String pattern, org.apache.thrift.async.AsyncMethodCallback<get_databases_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_databases(String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_databases_call method_call = new get_databases_call(pattern, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4382,7 +4386,7 @@ public class ThriftHiveMetastore {
 
     public static class get_databases_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String pattern;
-      public get_databases_call(String pattern, org.apache.thrift.async.AsyncMethodCallback<get_databases_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_databases_call(String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.pattern = pattern;
       }
@@ -4405,7 +4409,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_all_databases(org.apache.thrift.async.AsyncMethodCallback<get_all_databases_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_all_databases(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_all_databases_call method_call = new get_all_databases_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4413,7 +4417,7 @@ public class ThriftHiveMetastore {
     }
 
     public static class get_all_databases_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public get_all_databases_call(org.apache.thrift.async.AsyncMethodCallback<get_all_databases_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_all_databases_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -4434,7 +4438,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void alter_database(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback<alter_database_call> resultHandler) throws org.apache.thrift.TException {
+    public void alter_database(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       alter_database_call method_call = new alter_database_call(dbname, db, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4444,7 +4448,7 @@ public class ThriftHiveMetastore {
     public static class alter_database_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String dbname;
       private Database db;
-      public alter_database_call(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback<alter_database_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public alter_database_call(String dbname, Database db, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.dbname = dbname;
         this.db = db;
@@ -4469,7 +4473,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_type(String name, org.apache.thrift.async.AsyncMethodCallback<get_type_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_type(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_type_call method_call = new get_type_call(name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4478,7 +4482,7 @@ public class ThriftHiveMetastore {
 
     public static class get_type_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String name;
-      public get_type_call(String name, org.apache.thrift.async.AsyncMethodCallback<get_type_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_type_call(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.name = name;
       }
@@ -4501,7 +4505,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void create_type(Type type, org.apache.thrift.async.AsyncMethodCallback<create_type_call> resultHandler) throws org.apache.thrift.TException {
+    public void create_type(Type type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       create_type_call method_call = new create_type_call(type, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4510,7 +4514,7 @@ public class ThriftHiveMetastore {
 
     public static class create_type_call extends org.apache.thrift.async.TAsyncMethodCall {
       private Type type;
-      public create_type_call(Type type, org.apache.thrift.async.AsyncMethodCallback<create_type_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public create_type_call(Type type, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.type = type;
       }
@@ -4533,7 +4537,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void drop_type(String type, org.apache.thrift.async.AsyncMethodCallback<drop_type_call> resultHandler) throws org.apache.thrift.TException {
+    public void drop_type(String type, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       drop_type_call method_call = new drop_type_call(type, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4542,7 +4546,7 @@ public class ThriftHiveMetastore {
 
     public static class drop_type_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String type;
-      public drop_type_call(String type, org.apache.thrift.async.AsyncMethodCallback<drop_type_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public drop_type_call(String type, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.type = type;
       }
@@ -4565,7 +4569,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_type_all(String name, org.apache.thrift.async.AsyncMethodCallback<get_type_all_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_type_all(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_type_all_call method_call = new get_type_all_call(name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4574,7 +4578,7 @@ public class ThriftHiveMetastore {
 
     public static class get_type_all_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String name;
-      public get_type_all_call(String name, org.apache.thrift.async.AsyncMethodCallback<get_type_all_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_type_all_call(String name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.name = name;
       }
@@ -4597,7 +4601,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_fields(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<get_fields_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_fields(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_fields_call method_call = new get_fields_call(db_name, table_name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4607,7 +4611,7 @@ public class ThriftHiveMetastore {
     public static class get_fields_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String db_name;
       private String table_name;
-      public get_fields_call(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<get_fields_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_fields_call(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
         this.table_name = table_name;
@@ -4632,7 +4636,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_fields_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<get_fields_with_environment_context_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_fields_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_fields_with_environment_context_call method_call = new get_fields_with_environment_context_call(db_name, table_name, environment_context, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4643,7 +4647,7 @@ public class ThriftHiveMetastore {
       private String db_name;
       private String table_name;
       private EnvironmentContext environment_context;
-      public get_fields_with_environment_context_call(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<get_fields_with_environment_context_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_fields_with_environment_context_call(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
         this.table_name = table_name;
@@ -4670,7 +4674,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_schema(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<get_schema_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_schema(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_schema_call method_call = new get_schema_call(db_name, table_name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4680,7 +4684,7 @@ public class ThriftHiveMetastore {
     public static class get_schema_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String db_name;
       private String table_name;
-      public get_schema_call(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback<get_schema_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_schema_call(String db_name, String table_name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
         this.table_name = table_name;
@@ -4705,7 +4709,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_schema_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<get_schema_with_environment_context_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_schema_with_environment_context(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_schema_with_environment_context_call method_call = new get_schema_with_environment_context_call(db_name, table_name, environment_context, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4716,7 +4720,7 @@ public class ThriftHiveMetastore {
       private String db_name;
       private String table_name;
       private EnvironmentContext environment_context;
-      public get_schema_with_environment_context_call(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<get_schema_with_environment_context_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_schema_with_environment_context_call(String db_name, String table_name, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
         this.table_name = table_name;
@@ -4743,7 +4747,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void create_table(Table tbl, org.apache.thrift.async.AsyncMethodCallback<create_table_call> resultHandler) throws org.apache.thrift.TException {
+    public void create_table(Table tbl, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       create_table_call method_call = new create_table_call(tbl, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4752,7 +4756,7 @@ public class ThriftHiveMetastore {
 
     public static class create_table_call extends org.apache.thrift.async.TAsyncMethodCall {
       private Table tbl;
-      public create_table_call(Table tbl, org.apache.thrift.async.AsyncMethodCallback<create_table_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public create_table_call(Table tbl, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tbl = tbl;
       }
@@ -4775,7 +4779,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<create_table_with_environment_context_call> resultHandler) throws org.apache.thrift.TException {
+    public void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       create_table_with_environment_context_call method_call = new create_table_with_environment_context_call(tbl, environment_context, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4785,7 +4789,7 @@ public class ThriftHiveMetastore {
     public static class create_table_with_environment_context_call extends org.apache.thrift.async.TAsyncMethodCall {
       private Table tbl;
       private EnvironmentContext environment_context;
-      public create_table_with_environment_context_call(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<create_table_with_environment_context_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public create_table_with_environment_context_call(Table tbl, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.tbl = tbl;
         this.environment_context = environment_context;
@@ -4810,7 +4814,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void drop_table(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<drop_table_call> resultHandler) throws org.apache.thrift.TException {
+    public void drop_table(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       drop_table_call method_call = new drop_table_call(dbname, name, deleteData, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4821,7 +4825,7 @@ public class ThriftHiveMetastore {
       private String dbname;
       private String name;
       private boolean deleteData;
-      public drop_table_call(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback<drop_table_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public drop_table_call(String dbname, String name, boolean deleteData, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.dbname = dbname;
         this.name = name;
@@ -4848,7 +4852,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void drop_table_with_environment_context(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<drop_table_with_environment_context_call> resultHandler) throws org.apache.thrift.TException {
+    public void drop_table_with_environment_context(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       drop_table_with_environment_context_call method_call = new drop_table_with_environment_context_call(dbname, name, deleteData, environment_context, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4860,7 +4864,7 @@ public class ThriftHiveMetastore {
       private String name;
       private boolean deleteData;
       private EnvironmentContext environment_context;
-      public drop_table_with_environment_context_call(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback<drop_table_with_environment_context_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public drop_table_with_environment_context_call(String dbname, String name, boolean deleteData, EnvironmentContext environment_context, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.dbname = dbname;
         this.name = name;
@@ -4889,7 +4893,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_tables(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback<get_tables_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_tables(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_tables_call method_call = new get_tables_call(db_name, pattern, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4899,7 +4903,7 @@ public class ThriftHiveMetastore {
     public static class get_tables_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String db_name;
       private String pattern;
-      public get_tables_call(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback<get_tables_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_tables_call(String db_name, String pattern, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
         this.pattern = pattern;
@@ -4924,7 +4928,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_all_tables(String db_name, org.apache.thrift.async.AsyncMethodCallback<get_all_tables_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_all_tables(String db_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_all_tables_call method_call = new get_all_tables_call(db_name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4933,7 +4937,7 @@ public class ThriftHiveMetastore {
 
     public static class get_all_tables_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String db_name;
-      public get_all_tables_call(String db_name, org.apache.thrift.async.AsyncMethodCallback<get_all_tables_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_all_tables_call(String db_name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.db_name = db_name;
       }
@@ -4956,7 +4960,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_table(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback<get_table_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_table(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_table_call method_call = new get_table_call(dbname, tbl_name, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -4966,7 +4970,7 @@ public class ThriftHiveMetastore {
     public static class get_table_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String dbname;
       private String tbl_name;
-      public get_table_call(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback<get_table_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public get_table_call(String dbname, String tbl_name, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.dbname = dbname;
         this.tbl_name = tbl_name;
@@ -4991,7 +4995,7 @@ public class ThriftHiveMetastore {
       }
     }
 
-    public void get_table_objects_by_name(String dbname, List<String> tbl_names, org.apache.thrift.async.AsyncMethodCallback<get_table_objects_by_name_call> resultHandler) throws org.apache.thrift.TException {
+    public void get_table_objects_by_name(String dbname, List<String> tbl_names, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       get_table_objects_by_name_call method_call = new get_table_objects_by_name_call(dbname, tbl_names, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -5001,7 +5005,7 @@ public class ThriftHiveMetastore {
     public static class get_table_objects_by_name_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String dbname;
       private List<String> tbl_names;
-      public get_table_objects_by_name_call(String dbname, List<String> tbl_names, org.apache.thrift.async.AsyncMethodCallback<get_table_objects_by_name_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblock

<TRUNCATED>

[45/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.cpp b/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.cpp
index c7bf9ba..f61ac7d 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.h
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.h b/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.h
index 35a8a50..c95fec1 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.h
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[46/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
index 0f86117..d87c527 100644
--- a/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
+++ b/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -564,24 +564,26 @@ class ThriftHiveMetastoreNull : virtual public ThriftHiveMetastoreIf , virtual p
 
 typedef struct _ThriftHiveMetastore_getMetaConf_args__isset {
   _ThriftHiveMetastore_getMetaConf_args__isset() : key(false) {}
-  bool key;
+  bool key :1;
 } _ThriftHiveMetastore_getMetaConf_args__isset;
 
 class ThriftHiveMetastore_getMetaConf_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_getMetaConf_args(const ThriftHiveMetastore_getMetaConf_args&);
+  ThriftHiveMetastore_getMetaConf_args& operator=(const ThriftHiveMetastore_getMetaConf_args&);
   ThriftHiveMetastore_getMetaConf_args() : key() {
   }
 
-  virtual ~ThriftHiveMetastore_getMetaConf_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_getMetaConf_args() throw();
   std::string key;
 
   _ThriftHiveMetastore_getMetaConf_args__isset __isset;
 
-  void __set_key(const std::string& val) {
-    key = val;
-  }
+  void __set_key(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_getMetaConf_args & rhs) const
   {
@@ -598,47 +600,51 @@ class ThriftHiveMetastore_getMetaConf_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_getMetaConf_args& obj);
 };
 
 
 class ThriftHiveMetastore_getMetaConf_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_getMetaConf_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_getMetaConf_pargs() throw();
   const std::string* key;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_getMetaConf_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_getMetaConf_result__isset {
   _ThriftHiveMetastore_getMetaConf_result__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_getMetaConf_result__isset;
 
 class ThriftHiveMetastore_getMetaConf_result {
  public:
 
+  static const char* ascii_fingerprint; // = "FB3D66E547AE5D7F8EB046D752ECF5C1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFB,0x3D,0x66,0xE5,0x47,0xAE,0x5D,0x7F,0x8E,0xB0,0x46,0xD7,0x52,0xEC,0xF5,0xC1};
+
+  ThriftHiveMetastore_getMetaConf_result(const ThriftHiveMetastore_getMetaConf_result&);
+  ThriftHiveMetastore_getMetaConf_result& operator=(const ThriftHiveMetastore_getMetaConf_result&);
   ThriftHiveMetastore_getMetaConf_result() : success() {
   }
 
-  virtual ~ThriftHiveMetastore_getMetaConf_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_getMetaConf_result() throw();
   std::string success;
   MetaException o1;
 
   _ThriftHiveMetastore_getMetaConf_result__isset __isset;
 
-  void __set_success(const std::string& val) {
-    success = val;
-  }
+  void __set_success(const std::string& val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_getMetaConf_result & rhs) const
   {
@@ -657,20 +663,23 @@ class ThriftHiveMetastore_getMetaConf_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_getMetaConf_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_getMetaConf_presult__isset {
   _ThriftHiveMetastore_getMetaConf_presult__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_getMetaConf_presult__isset;
 
 class ThriftHiveMetastore_getMetaConf_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "FB3D66E547AE5D7F8EB046D752ECF5C1";
+  static const uint8_t binary_fingerprint[16]; // = {0xFB,0x3D,0x66,0xE5,0x47,0xAE,0x5D,0x7F,0x8E,0xB0,0x46,0xD7,0x52,0xEC,0xF5,0xC1};
 
-  virtual ~ThriftHiveMetastore_getMetaConf_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_getMetaConf_presult() throw();
   std::string* success;
   MetaException o1;
 
@@ -678,34 +687,35 @@ class ThriftHiveMetastore_getMetaConf_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_getMetaConf_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_setMetaConf_args__isset {
   _ThriftHiveMetastore_setMetaConf_args__isset() : key(false), value(false) {}
-  bool key;
-  bool value;
+  bool key :1;
+  bool value :1;
 } _ThriftHiveMetastore_setMetaConf_args__isset;
 
 class ThriftHiveMetastore_setMetaConf_args {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
+
+  ThriftHiveMetastore_setMetaConf_args(const ThriftHiveMetastore_setMetaConf_args&);
+  ThriftHiveMetastore_setMetaConf_args& operator=(const ThriftHiveMetastore_setMetaConf_args&);
   ThriftHiveMetastore_setMetaConf_args() : key(), value() {
   }
 
-  virtual ~ThriftHiveMetastore_setMetaConf_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_setMetaConf_args() throw();
   std::string key;
   std::string value;
 
   _ThriftHiveMetastore_setMetaConf_args__isset __isset;
 
-  void __set_key(const std::string& val) {
-    key = val;
-  }
+  void __set_key(const std::string& val);
 
-  void __set_value(const std::string& val) {
-    value = val;
-  }
+  void __set_value(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_setMetaConf_args & rhs) const
   {
@@ -724,42 +734,48 @@ class ThriftHiveMetastore_setMetaConf_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_setMetaConf_args& obj);
 };
 
 
 class ThriftHiveMetastore_setMetaConf_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
-  virtual ~ThriftHiveMetastore_setMetaConf_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_setMetaConf_pargs() throw();
   const std::string* key;
   const std::string* value;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_setMetaConf_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_setMetaConf_result__isset {
   _ThriftHiveMetastore_setMetaConf_result__isset() : o1(false) {}
-  bool o1;
+  bool o1 :1;
 } _ThriftHiveMetastore_setMetaConf_result__isset;
 
 class ThriftHiveMetastore_setMetaConf_result {
  public:
 
+  static const char* ascii_fingerprint; // = "771E7EF40B572D2BFAB12C49547ADCBF";
+  static const uint8_t binary_fingerprint[16]; // = {0x77,0x1E,0x7E,0xF4,0x0B,0x57,0x2D,0x2B,0xFA,0xB1,0x2C,0x49,0x54,0x7A,0xDC,0xBF};
+
+  ThriftHiveMetastore_setMetaConf_result(const ThriftHiveMetastore_setMetaConf_result&);
+  ThriftHiveMetastore_setMetaConf_result& operator=(const ThriftHiveMetastore_setMetaConf_result&);
   ThriftHiveMetastore_setMetaConf_result() {
   }
 
-  virtual ~ThriftHiveMetastore_setMetaConf_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_setMetaConf_result() throw();
   MetaException o1;
 
   _ThriftHiveMetastore_setMetaConf_result__isset __isset;
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_setMetaConf_result & rhs) const
   {
@@ -776,47 +792,53 @@ class ThriftHiveMetastore_setMetaConf_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_setMetaConf_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_setMetaConf_presult__isset {
   _ThriftHiveMetastore_setMetaConf_presult__isset() : o1(false) {}
-  bool o1;
+  bool o1 :1;
 } _ThriftHiveMetastore_setMetaConf_presult__isset;
 
 class ThriftHiveMetastore_setMetaConf_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "771E7EF40B572D2BFAB12C49547ADCBF";
+  static const uint8_t binary_fingerprint[16]; // = {0x77,0x1E,0x7E,0xF4,0x0B,0x57,0x2D,0x2B,0xFA,0xB1,0x2C,0x49,0x54,0x7A,0xDC,0xBF};
 
-  virtual ~ThriftHiveMetastore_setMetaConf_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_setMetaConf_presult() throw();
   MetaException o1;
 
   _ThriftHiveMetastore_setMetaConf_presult__isset __isset;
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_setMetaConf_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_database_args__isset {
   _ThriftHiveMetastore_create_database_args__isset() : database(false) {}
-  bool database;
+  bool database :1;
 } _ThriftHiveMetastore_create_database_args__isset;
 
 class ThriftHiveMetastore_create_database_args {
  public:
 
+  static const char* ascii_fingerprint; // = "BAA173319AAB1B660ECE7D895D8F1A31";
+  static const uint8_t binary_fingerprint[16]; // = {0xBA,0xA1,0x73,0x31,0x9A,0xAB,0x1B,0x66,0x0E,0xCE,0x7D,0x89,0x5D,0x8F,0x1A,0x31};
+
+  ThriftHiveMetastore_create_database_args(const ThriftHiveMetastore_create_database_args&);
+  ThriftHiveMetastore_create_database_args& operator=(const ThriftHiveMetastore_create_database_args&);
   ThriftHiveMetastore_create_database_args() {
   }
 
-  virtual ~ThriftHiveMetastore_create_database_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_database_args() throw();
   Database database;
 
   _ThriftHiveMetastore_create_database_args__isset __isset;
 
-  void __set_database(const Database& val) {
-    database = val;
-  }
+  void __set_database(const Database& val);
 
   bool operator == (const ThriftHiveMetastore_create_database_args & rhs) const
   {
@@ -833,53 +855,55 @@ class ThriftHiveMetastore_create_database_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_database_args& obj);
 };
 
 
 class ThriftHiveMetastore_create_database_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "BAA173319AAB1B660ECE7D895D8F1A31";
+  static const uint8_t binary_fingerprint[16]; // = {0xBA,0xA1,0x73,0x31,0x9A,0xAB,0x1B,0x66,0x0E,0xCE,0x7D,0x89,0x5D,0x8F,0x1A,0x31};
 
-  virtual ~ThriftHiveMetastore_create_database_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_create_database_pargs() throw();
   const Database* database;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_database_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_database_result__isset {
   _ThriftHiveMetastore_create_database_result__isset() : o1(false), o2(false), o3(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_create_database_result__isset;
 
 class ThriftHiveMetastore_create_database_result {
  public:
 
+  static const char* ascii_fingerprint; // = "2E72786EE0F17DA00FC5BDED362FE255";
+  static const uint8_t binary_fingerprint[16]; // = {0x2E,0x72,0x78,0x6E,0xE0,0xF1,0x7D,0xA0,0x0F,0xC5,0xBD,0xED,0x36,0x2F,0xE2,0x55};
+
+  ThriftHiveMetastore_create_database_result(const ThriftHiveMetastore_create_database_result&);
+  ThriftHiveMetastore_create_database_result& operator=(const ThriftHiveMetastore_create_database_result&);
   ThriftHiveMetastore_create_database_result() {
   }
 
-  virtual ~ThriftHiveMetastore_create_database_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_database_result() throw();
   AlreadyExistsException o1;
   InvalidObjectException o2;
   MetaException o3;
 
   _ThriftHiveMetastore_create_database_result__isset __isset;
 
-  void __set_o1(const AlreadyExistsException& val) {
-    o1 = val;
-  }
+  void __set_o1(const AlreadyExistsException& val);
 
-  void __set_o2(const InvalidObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const InvalidObjectException& val);
 
-  void __set_o3(const MetaException& val) {
-    o3 = val;
-  }
+  void __set_o3(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_create_database_result & rhs) const
   {
@@ -900,21 +924,24 @@ class ThriftHiveMetastore_create_database_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_database_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_database_presult__isset {
   _ThriftHiveMetastore_create_database_presult__isset() : o1(false), o2(false), o3(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_create_database_presult__isset;
 
 class ThriftHiveMetastore_create_database_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "2E72786EE0F17DA00FC5BDED362FE255";
+  static const uint8_t binary_fingerprint[16]; // = {0x2E,0x72,0x78,0x6E,0xE0,0xF1,0x7D,0xA0,0x0F,0xC5,0xBD,0xED,0x36,0x2F,0xE2,0x55};
 
-  virtual ~ThriftHiveMetastore_create_database_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_create_database_presult() throw();
   AlreadyExistsException o1;
   InvalidObjectException o2;
   MetaException o3;
@@ -923,28 +950,31 @@ class ThriftHiveMetastore_create_database_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_database_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_database_args__isset {
   _ThriftHiveMetastore_get_database_args__isset() : name(false) {}
-  bool name;
+  bool name :1;
 } _ThriftHiveMetastore_get_database_args__isset;
 
 class ThriftHiveMetastore_get_database_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_get_database_args(const ThriftHiveMetastore_get_database_args&);
+  ThriftHiveMetastore_get_database_args& operator=(const ThriftHiveMetastore_get_database_args&);
   ThriftHiveMetastore_get_database_args() : name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_database_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_database_args() throw();
   std::string name;
 
   _ThriftHiveMetastore_get_database_args__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_database_args & rhs) const
   {
@@ -961,53 +991,55 @@ class ThriftHiveMetastore_get_database_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_database_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_database_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_get_database_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_database_pargs() throw();
   const std::string* name;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_database_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_database_result__isset {
   _ThriftHiveMetastore_get_database_result__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_database_result__isset;
 
 class ThriftHiveMetastore_get_database_result {
  public:
 
+  static const char* ascii_fingerprint; // = "C73ECEC4971924DCA9053333CB4A89A0";
+  static const uint8_t binary_fingerprint[16]; // = {0xC7,0x3E,0xCE,0xC4,0x97,0x19,0x24,0xDC,0xA9,0x05,0x33,0x33,0xCB,0x4A,0x89,0xA0};
+
+  ThriftHiveMetastore_get_database_result(const ThriftHiveMetastore_get_database_result&);
+  ThriftHiveMetastore_get_database_result& operator=(const ThriftHiveMetastore_get_database_result&);
   ThriftHiveMetastore_get_database_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_database_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_database_result() throw();
   Database success;
   NoSuchObjectException o1;
   MetaException o2;
 
   _ThriftHiveMetastore_get_database_result__isset __isset;
 
-  void __set_success(const Database& val) {
-    success = val;
-  }
+  void __set_success(const Database& val);
 
-  void __set_o1(const NoSuchObjectException& val) {
-    o1 = val;
-  }
+  void __set_o1(const NoSuchObjectException& val);
 
-  void __set_o2(const MetaException& val) {
-    o2 = val;
-  }
+  void __set_o2(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_get_database_result & rhs) const
   {
@@ -1028,21 +1060,24 @@ class ThriftHiveMetastore_get_database_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_database_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_database_presult__isset {
   _ThriftHiveMetastore_get_database_presult__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_database_presult__isset;
 
 class ThriftHiveMetastore_get_database_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "C73ECEC4971924DCA9053333CB4A89A0";
+  static const uint8_t binary_fingerprint[16]; // = {0xC7,0x3E,0xCE,0xC4,0x97,0x19,0x24,0xDC,0xA9,0x05,0x33,0x33,0xCB,0x4A,0x89,0xA0};
 
-  virtual ~ThriftHiveMetastore_get_database_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_database_presult() throw();
   Database* success;
   NoSuchObjectException o1;
   MetaException o2;
@@ -1051,40 +1086,39 @@ class ThriftHiveMetastore_get_database_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_database_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_database_args__isset {
   _ThriftHiveMetastore_drop_database_args__isset() : name(false), deleteData(false), cascade(false) {}
-  bool name;
-  bool deleteData;
-  bool cascade;
+  bool name :1;
+  bool deleteData :1;
+  bool cascade :1;
 } _ThriftHiveMetastore_drop_database_args__isset;
 
 class ThriftHiveMetastore_drop_database_args {
  public:
 
+  static const char* ascii_fingerprint; // = "B8E1E91B0E4D1772237E387EEB23B1B0";
+  static const uint8_t binary_fingerprint[16]; // = {0xB8,0xE1,0xE9,0x1B,0x0E,0x4D,0x17,0x72,0x23,0x7E,0x38,0x7E,0xEB,0x23,0xB1,0xB0};
+
+  ThriftHiveMetastore_drop_database_args(const ThriftHiveMetastore_drop_database_args&);
+  ThriftHiveMetastore_drop_database_args& operator=(const ThriftHiveMetastore_drop_database_args&);
   ThriftHiveMetastore_drop_database_args() : name(), deleteData(0), cascade(0) {
   }
 
-  virtual ~ThriftHiveMetastore_drop_database_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_drop_database_args() throw();
   std::string name;
   bool deleteData;
   bool cascade;
 
   _ThriftHiveMetastore_drop_database_args__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
-  void __set_deleteData(const bool val) {
-    deleteData = val;
-  }
+  void __set_deleteData(const bool val);
 
-  void __set_cascade(const bool val) {
-    cascade = val;
-  }
+  void __set_cascade(const bool val);
 
   bool operator == (const ThriftHiveMetastore_drop_database_args & rhs) const
   {
@@ -1105,55 +1139,57 @@ class ThriftHiveMetastore_drop_database_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_database_args& obj);
 };
 
 
 class ThriftHiveMetastore_drop_database_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "B8E1E91B0E4D1772237E387EEB23B1B0";
+  static const uint8_t binary_fingerprint[16]; // = {0xB8,0xE1,0xE9,0x1B,0x0E,0x4D,0x17,0x72,0x23,0x7E,0x38,0x7E,0xEB,0x23,0xB1,0xB0};
 
-  virtual ~ThriftHiveMetastore_drop_database_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_drop_database_pargs() throw();
   const std::string* name;
   const bool* deleteData;
   const bool* cascade;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_database_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_database_result__isset {
   _ThriftHiveMetastore_drop_database_result__isset() : o1(false), o2(false), o3(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_drop_database_result__isset;
 
 class ThriftHiveMetastore_drop_database_result {
  public:
 
+  static const char* ascii_fingerprint; // = "2E72786EE0F17DA00FC5BDED362FE255";
+  static const uint8_t binary_fingerprint[16]; // = {0x2E,0x72,0x78,0x6E,0xE0,0xF1,0x7D,0xA0,0x0F,0xC5,0xBD,0xED,0x36,0x2F,0xE2,0x55};
+
+  ThriftHiveMetastore_drop_database_result(const ThriftHiveMetastore_drop_database_result&);
+  ThriftHiveMetastore_drop_database_result& operator=(const ThriftHiveMetastore_drop_database_result&);
   ThriftHiveMetastore_drop_database_result() {
   }
 
-  virtual ~ThriftHiveMetastore_drop_database_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_drop_database_result() throw();
   NoSuchObjectException o1;
   InvalidOperationException o2;
   MetaException o3;
 
   _ThriftHiveMetastore_drop_database_result__isset __isset;
 
-  void __set_o1(const NoSuchObjectException& val) {
-    o1 = val;
-  }
+  void __set_o1(const NoSuchObjectException& val);
 
-  void __set_o2(const InvalidOperationException& val) {
-    o2 = val;
-  }
+  void __set_o2(const InvalidOperationException& val);
 
-  void __set_o3(const MetaException& val) {
-    o3 = val;
-  }
+  void __set_o3(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_drop_database_result & rhs) const
   {
@@ -1174,21 +1210,24 @@ class ThriftHiveMetastore_drop_database_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_database_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_database_presult__isset {
   _ThriftHiveMetastore_drop_database_presult__isset() : o1(false), o2(false), o3(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_drop_database_presult__isset;
 
 class ThriftHiveMetastore_drop_database_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "2E72786EE0F17DA00FC5BDED362FE255";
+  static const uint8_t binary_fingerprint[16]; // = {0x2E,0x72,0x78,0x6E,0xE0,0xF1,0x7D,0xA0,0x0F,0xC5,0xBD,0xED,0x36,0x2F,0xE2,0x55};
 
-  virtual ~ThriftHiveMetastore_drop_database_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_drop_database_presult() throw();
   NoSuchObjectException o1;
   InvalidOperationException o2;
   MetaException o3;
@@ -1197,28 +1236,31 @@ class ThriftHiveMetastore_drop_database_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_database_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_databases_args__isset {
   _ThriftHiveMetastore_get_databases_args__isset() : pattern(false) {}
-  bool pattern;
+  bool pattern :1;
 } _ThriftHiveMetastore_get_databases_args__isset;
 
 class ThriftHiveMetastore_get_databases_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_get_databases_args(const ThriftHiveMetastore_get_databases_args&);
+  ThriftHiveMetastore_get_databases_args& operator=(const ThriftHiveMetastore_get_databases_args&);
   ThriftHiveMetastore_get_databases_args() : pattern() {
   }
 
-  virtual ~ThriftHiveMetastore_get_databases_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_databases_args() throw();
   std::string pattern;
 
   _ThriftHiveMetastore_get_databases_args__isset __isset;
 
-  void __set_pattern(const std::string& val) {
-    pattern = val;
-  }
+  void __set_pattern(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_databases_args & rhs) const
   {
@@ -1235,47 +1277,51 @@ class ThriftHiveMetastore_get_databases_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_databases_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_databases_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_get_databases_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_databases_pargs() throw();
   const std::string* pattern;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_databases_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_databases_result__isset {
   _ThriftHiveMetastore_get_databases_result__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_get_databases_result__isset;
 
 class ThriftHiveMetastore_get_databases_result {
  public:
 
+  static const char* ascii_fingerprint; // = "96F383CF9CB8BE09061ECB825FE717B6";
+  static const uint8_t binary_fingerprint[16]; // = {0x96,0xF3,0x83,0xCF,0x9C,0xB8,0xBE,0x09,0x06,0x1E,0xCB,0x82,0x5F,0xE7,0x17,0xB6};
+
+  ThriftHiveMetastore_get_databases_result(const ThriftHiveMetastore_get_databases_result&);
+  ThriftHiveMetastore_get_databases_result& operator=(const ThriftHiveMetastore_get_databases_result&);
   ThriftHiveMetastore_get_databases_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_databases_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_databases_result() throw();
   std::vector<std::string>  success;
   MetaException o1;
 
   _ThriftHiveMetastore_get_databases_result__isset __isset;
 
-  void __set_success(const std::vector<std::string> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<std::string> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_get_databases_result & rhs) const
   {
@@ -1294,20 +1340,23 @@ class ThriftHiveMetastore_get_databases_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_databases_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_databases_presult__isset {
   _ThriftHiveMetastore_get_databases_presult__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_get_databases_presult__isset;
 
 class ThriftHiveMetastore_get_databases_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "96F383CF9CB8BE09061ECB825FE717B6";
+  static const uint8_t binary_fingerprint[16]; // = {0x96,0xF3,0x83,0xCF,0x9C,0xB8,0xBE,0x09,0x06,0x1E,0xCB,0x82,0x5F,0xE7,0x17,0xB6};
 
-  virtual ~ThriftHiveMetastore_get_databases_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_databases_presult() throw();
   std::vector<std::string> * success;
   MetaException o1;
 
@@ -1315,17 +1364,22 @@ class ThriftHiveMetastore_get_databases_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_databases_presult& obj);
 };
 
 
 class ThriftHiveMetastore_get_all_databases_args {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
+
+  ThriftHiveMetastore_get_all_databases_args(const ThriftHiveMetastore_get_all_databases_args&);
+  ThriftHiveMetastore_get_all_databases_args& operator=(const ThriftHiveMetastore_get_all_databases_args&);
   ThriftHiveMetastore_get_all_databases_args() {
   }
 
-  virtual ~ThriftHiveMetastore_get_all_databases_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_all_databases_args() throw();
 
   bool operator == (const ThriftHiveMetastore_get_all_databases_args & /* rhs */) const
   {
@@ -1340,46 +1394,50 @@ class ThriftHiveMetastore_get_all_databases_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_all_databases_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_all_databases_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "99914B932BD37A50B983C5E7C90AE93B";
+  static const uint8_t binary_fingerprint[16]; // = {0x99,0x91,0x4B,0x93,0x2B,0xD3,0x7A,0x50,0xB9,0x83,0xC5,0xE7,0xC9,0x0A,0xE9,0x3B};
 
-  virtual ~ThriftHiveMetastore_get_all_databases_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_all_databases_pargs() throw();
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_all_databases_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_all_databases_result__isset {
   _ThriftHiveMetastore_get_all_databases_result__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_get_all_databases_result__isset;
 
 class ThriftHiveMetastore_get_all_databases_result {
  public:
 
+  static const char* ascii_fingerprint; // = "96F383CF9CB8BE09061ECB825FE717B6";
+  static const uint8_t binary_fingerprint[16]; // = {0x96,0xF3,0x83,0xCF,0x9C,0xB8,0xBE,0x09,0x06,0x1E,0xCB,0x82,0x5F,0xE7,0x17,0xB6};
+
+  ThriftHiveMetastore_get_all_databases_result(const ThriftHiveMetastore_get_all_databases_result&);
+  ThriftHiveMetastore_get_all_databases_result& operator=(const ThriftHiveMetastore_get_all_databases_result&);
   ThriftHiveMetastore_get_all_databases_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_all_databases_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_all_databases_result() throw();
   std::vector<std::string>  success;
   MetaException o1;
 
   _ThriftHiveMetastore_get_all_databases_result__isset __isset;
 
-  void __set_success(const std::vector<std::string> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<std::string> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_get_all_databases_result & rhs) const
   {
@@ -1398,20 +1456,23 @@ class ThriftHiveMetastore_get_all_databases_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_all_databases_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_all_databases_presult__isset {
   _ThriftHiveMetastore_get_all_databases_presult__isset() : success(false), o1(false) {}
-  bool success;
-  bool o1;
+  bool success :1;
+  bool o1 :1;
 } _ThriftHiveMetastore_get_all_databases_presult__isset;
 
 class ThriftHiveMetastore_get_all_databases_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "96F383CF9CB8BE09061ECB825FE717B6";
+  static const uint8_t binary_fingerprint[16]; // = {0x96,0xF3,0x83,0xCF,0x9C,0xB8,0xBE,0x09,0x06,0x1E,0xCB,0x82,0x5F,0xE7,0x17,0xB6};
 
-  virtual ~ThriftHiveMetastore_get_all_databases_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_all_databases_presult() throw();
   std::vector<std::string> * success;
   MetaException o1;
 
@@ -1419,34 +1480,35 @@ class ThriftHiveMetastore_get_all_databases_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_all_databases_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_alter_database_args__isset {
   _ThriftHiveMetastore_alter_database_args__isset() : dbname(false), db(false) {}
-  bool dbname;
-  bool db;
+  bool dbname :1;
+  bool db :1;
 } _ThriftHiveMetastore_alter_database_args__isset;
 
 class ThriftHiveMetastore_alter_database_args {
  public:
 
+  static const char* ascii_fingerprint; // = "B314C1FCA7295CFE5872A037139333A5";
+  static const uint8_t binary_fingerprint[16]; // = {0xB3,0x14,0xC1,0xFC,0xA7,0x29,0x5C,0xFE,0x58,0x72,0xA0,0x37,0x13,0x93,0x33,0xA5};
+
+  ThriftHiveMetastore_alter_database_args(const ThriftHiveMetastore_alter_database_args&);
+  ThriftHiveMetastore_alter_database_args& operator=(const ThriftHiveMetastore_alter_database_args&);
   ThriftHiveMetastore_alter_database_args() : dbname() {
   }
 
-  virtual ~ThriftHiveMetastore_alter_database_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_alter_database_args() throw();
   std::string dbname;
   Database db;
 
   _ThriftHiveMetastore_alter_database_args__isset __isset;
 
-  void __set_dbname(const std::string& val) {
-    dbname = val;
-  }
+  void __set_dbname(const std::string& val);
 
-  void __set_db(const Database& val) {
-    db = val;
-  }
+  void __set_db(const Database& val);
 
   bool operator == (const ThriftHiveMetastore_alter_database_args & rhs) const
   {
@@ -1465,48 +1527,52 @@ class ThriftHiveMetastore_alter_database_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_alter_database_args& obj);
 };
 
 
 class ThriftHiveMetastore_alter_database_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "B314C1FCA7295CFE5872A037139333A5";
+  static const uint8_t binary_fingerprint[16]; // = {0xB3,0x14,0xC1,0xFC,0xA7,0x29,0x5C,0xFE,0x58,0x72,0xA0,0x37,0x13,0x93,0x33,0xA5};
 
-  virtual ~ThriftHiveMetastore_alter_database_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_alter_database_pargs() throw();
   const std::string* dbname;
   const Database* db;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_alter_database_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_alter_database_result__isset {
   _ThriftHiveMetastore_alter_database_result__isset() : o1(false), o2(false) {}
-  bool o1;
-  bool o2;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_alter_database_result__isset;
 
 class ThriftHiveMetastore_alter_database_result {
  public:
 
+  static const char* ascii_fingerprint; // = "A963880F55F6F22FCC67AD7BA0E1894D";
+  static const uint8_t binary_fingerprint[16]; // = {0xA9,0x63,0x88,0x0F,0x55,0xF6,0xF2,0x2F,0xCC,0x67,0xAD,0x7B,0xA0,0xE1,0x89,0x4D};
+
+  ThriftHiveMetastore_alter_database_result(const ThriftHiveMetastore_alter_database_result&);
+  ThriftHiveMetastore_alter_database_result& operator=(const ThriftHiveMetastore_alter_database_result&);
   ThriftHiveMetastore_alter_database_result() {
   }
 
-  virtual ~ThriftHiveMetastore_alter_database_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_alter_database_result() throw();
   MetaException o1;
   NoSuchObjectException o2;
 
   _ThriftHiveMetastore_alter_database_result__isset __isset;
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const NoSuchObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const NoSuchObjectException& val);
 
   bool operator == (const ThriftHiveMetastore_alter_database_result & rhs) const
   {
@@ -1525,20 +1591,23 @@ class ThriftHiveMetastore_alter_database_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_alter_database_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_alter_database_presult__isset {
   _ThriftHiveMetastore_alter_database_presult__isset() : o1(false), o2(false) {}
-  bool o1;
-  bool o2;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_alter_database_presult__isset;
 
 class ThriftHiveMetastore_alter_database_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "A963880F55F6F22FCC67AD7BA0E1894D";
+  static const uint8_t binary_fingerprint[16]; // = {0xA9,0x63,0x88,0x0F,0x55,0xF6,0xF2,0x2F,0xCC,0x67,0xAD,0x7B,0xA0,0xE1,0x89,0x4D};
 
-  virtual ~ThriftHiveMetastore_alter_database_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_alter_database_presult() throw();
   MetaException o1;
   NoSuchObjectException o2;
 
@@ -1546,28 +1615,31 @@ class ThriftHiveMetastore_alter_database_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_alter_database_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_args__isset {
   _ThriftHiveMetastore_get_type_args__isset() : name(false) {}
-  bool name;
+  bool name :1;
 } _ThriftHiveMetastore_get_type_args__isset;
 
 class ThriftHiveMetastore_get_type_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_get_type_args(const ThriftHiveMetastore_get_type_args&);
+  ThriftHiveMetastore_get_type_args& operator=(const ThriftHiveMetastore_get_type_args&);
   ThriftHiveMetastore_get_type_args() : name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_type_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_type_args() throw();
   std::string name;
 
   _ThriftHiveMetastore_get_type_args__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_type_args & rhs) const
   {
@@ -1584,53 +1656,55 @@ class ThriftHiveMetastore_get_type_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_type_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_get_type_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_type_pargs() throw();
   const std::string* name;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_result__isset {
   _ThriftHiveMetastore_get_type_result__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_type_result__isset;
 
 class ThriftHiveMetastore_get_type_result {
  public:
 
+  static const char* ascii_fingerprint; // = "FB3C6A03581A125ACD392DBF486E3393";
+  static const uint8_t binary_fingerprint[16]; // = {0xFB,0x3C,0x6A,0x03,0x58,0x1A,0x12,0x5A,0xCD,0x39,0x2D,0xBF,0x48,0x6E,0x33,0x93};
+
+  ThriftHiveMetastore_get_type_result(const ThriftHiveMetastore_get_type_result&);
+  ThriftHiveMetastore_get_type_result& operator=(const ThriftHiveMetastore_get_type_result&);
   ThriftHiveMetastore_get_type_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_type_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_type_result() throw();
   Type success;
   MetaException o1;
   NoSuchObjectException o2;
 
   _ThriftHiveMetastore_get_type_result__isset __isset;
 
-  void __set_success(const Type& val) {
-    success = val;
-  }
+  void __set_success(const Type& val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const NoSuchObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const NoSuchObjectException& val);
 
   bool operator == (const ThriftHiveMetastore_get_type_result & rhs) const
   {
@@ -1651,21 +1725,24 @@ class ThriftHiveMetastore_get_type_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_presult__isset {
   _ThriftHiveMetastore_get_type_presult__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_type_presult__isset;
 
 class ThriftHiveMetastore_get_type_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "FB3C6A03581A125ACD392DBF486E3393";
+  static const uint8_t binary_fingerprint[16]; // = {0xFB,0x3C,0x6A,0x03,0x58,0x1A,0x12,0x5A,0xCD,0x39,0x2D,0xBF,0x48,0x6E,0x33,0x93};
 
-  virtual ~ThriftHiveMetastore_get_type_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_type_presult() throw();
   Type* success;
   MetaException o1;
   NoSuchObjectException o2;
@@ -1674,28 +1751,31 @@ class ThriftHiveMetastore_get_type_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_type_args__isset {
   _ThriftHiveMetastore_create_type_args__isset() : type(false) {}
-  bool type;
+  bool type :1;
 } _ThriftHiveMetastore_create_type_args__isset;
 
 class ThriftHiveMetastore_create_type_args {
  public:
 
+  static const char* ascii_fingerprint; // = "9A5D4BC8553C4C253DA189914EB026F0";
+  static const uint8_t binary_fingerprint[16]; // = {0x9A,0x5D,0x4B,0xC8,0x55,0x3C,0x4C,0x25,0x3D,0xA1,0x89,0x91,0x4E,0xB0,0x26,0xF0};
+
+  ThriftHiveMetastore_create_type_args(const ThriftHiveMetastore_create_type_args&);
+  ThriftHiveMetastore_create_type_args& operator=(const ThriftHiveMetastore_create_type_args&);
   ThriftHiveMetastore_create_type_args() {
   }
 
-  virtual ~ThriftHiveMetastore_create_type_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_type_args() throw();
   Type type;
 
   _ThriftHiveMetastore_create_type_args__isset __isset;
 
-  void __set_type(const Type& val) {
-    type = val;
-  }
+  void __set_type(const Type& val);
 
   bool operator == (const ThriftHiveMetastore_create_type_args & rhs) const
   {
@@ -1712,37 +1792,45 @@ class ThriftHiveMetastore_create_type_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_type_args& obj);
 };
 
 
 class ThriftHiveMetastore_create_type_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "9A5D4BC8553C4C253DA189914EB026F0";
+  static const uint8_t binary_fingerprint[16]; // = {0x9A,0x5D,0x4B,0xC8,0x55,0x3C,0x4C,0x25,0x3D,0xA1,0x89,0x91,0x4E,0xB0,0x26,0xF0};
 
-  virtual ~ThriftHiveMetastore_create_type_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_create_type_pargs() throw();
   const Type* type;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_type_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_type_result__isset {
   _ThriftHiveMetastore_create_type_result__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_create_type_result__isset;
 
 class ThriftHiveMetastore_create_type_result {
  public:
 
+  static const char* ascii_fingerprint; // = "BEFA80ACD0D12B069F160582E1F44215";
+  static const uint8_t binary_fingerprint[16]; // = {0xBE,0xFA,0x80,0xAC,0xD0,0xD1,0x2B,0x06,0x9F,0x16,0x05,0x82,0xE1,0xF4,0x42,0x15};
+
+  ThriftHiveMetastore_create_type_result(const ThriftHiveMetastore_create_type_result&);
+  ThriftHiveMetastore_create_type_result& operator=(const ThriftHiveMetastore_create_type_result&);
   ThriftHiveMetastore_create_type_result() : success(0) {
   }
 
-  virtual ~ThriftHiveMetastore_create_type_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_type_result() throw();
   bool success;
   AlreadyExistsException o1;
   InvalidObjectException o2;
@@ -1750,21 +1838,13 @@ class ThriftHiveMetastore_create_type_result {
 
   _ThriftHiveMetastore_create_type_result__isset __isset;
 
-  void __set_success(const bool val) {
-    success = val;
-  }
+  void __set_success(const bool val);
 
-  void __set_o1(const AlreadyExistsException& val) {
-    o1 = val;
-  }
+  void __set_o1(const AlreadyExistsException& val);
 
-  void __set_o2(const InvalidObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const InvalidObjectException& val);
 
-  void __set_o3(const MetaException& val) {
-    o3 = val;
-  }
+  void __set_o3(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_create_type_result & rhs) const
   {
@@ -1787,22 +1867,25 @@ class ThriftHiveMetastore_create_type_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_type_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_type_presult__isset {
   _ThriftHiveMetastore_create_type_presult__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_create_type_presult__isset;
 
 class ThriftHiveMetastore_create_type_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "BEFA80ACD0D12B069F160582E1F44215";
+  static const uint8_t binary_fingerprint[16]; // = {0xBE,0xFA,0x80,0xAC,0xD0,0xD1,0x2B,0x06,0x9F,0x16,0x05,0x82,0xE1,0xF4,0x42,0x15};
 
-  virtual ~ThriftHiveMetastore_create_type_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_create_type_presult() throw();
   bool* success;
   AlreadyExistsException o1;
   InvalidObjectException o2;
@@ -1812,28 +1895,31 @@ class ThriftHiveMetastore_create_type_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_type_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_type_args__isset {
   _ThriftHiveMetastore_drop_type_args__isset() : type(false) {}
-  bool type;
+  bool type :1;
 } _ThriftHiveMetastore_drop_type_args__isset;
 
 class ThriftHiveMetastore_drop_type_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_drop_type_args(const ThriftHiveMetastore_drop_type_args&);
+  ThriftHiveMetastore_drop_type_args& operator=(const ThriftHiveMetastore_drop_type_args&);
   ThriftHiveMetastore_drop_type_args() : type() {
   }
 
-  virtual ~ThriftHiveMetastore_drop_type_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_drop_type_args() throw();
   std::string type;
 
   _ThriftHiveMetastore_drop_type_args__isset __isset;
 
-  void __set_type(const std::string& val) {
-    type = val;
-  }
+  void __set_type(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_drop_type_args & rhs) const
   {
@@ -1850,53 +1936,55 @@ class ThriftHiveMetastore_drop_type_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_type_args& obj);
 };
 
 
 class ThriftHiveMetastore_drop_type_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_drop_type_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_drop_type_pargs() throw();
   const std::string* type;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_type_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_type_result__isset {
   _ThriftHiveMetastore_drop_type_result__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_drop_type_result__isset;
 
 class ThriftHiveMetastore_drop_type_result {
  public:
 
+  static const char* ascii_fingerprint; // = "3499095F5992356B85332339F1B55814";
+  static const uint8_t binary_fingerprint[16]; // = {0x34,0x99,0x09,0x5F,0x59,0x92,0x35,0x6B,0x85,0x33,0x23,0x39,0xF1,0xB5,0x58,0x14};
+
+  ThriftHiveMetastore_drop_type_result(const ThriftHiveMetastore_drop_type_result&);
+  ThriftHiveMetastore_drop_type_result& operator=(const ThriftHiveMetastore_drop_type_result&);
   ThriftHiveMetastore_drop_type_result() : success(0) {
   }
 
-  virtual ~ThriftHiveMetastore_drop_type_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_drop_type_result() throw();
   bool success;
   MetaException o1;
   NoSuchObjectException o2;
 
   _ThriftHiveMetastore_drop_type_result__isset __isset;
 
-  void __set_success(const bool val) {
-    success = val;
-  }
+  void __set_success(const bool val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const NoSuchObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const NoSuchObjectException& val);
 
   bool operator == (const ThriftHiveMetastore_drop_type_result & rhs) const
   {
@@ -1917,21 +2005,24 @@ class ThriftHiveMetastore_drop_type_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_type_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_drop_type_presult__isset {
   _ThriftHiveMetastore_drop_type_presult__isset() : success(false), o1(false), o2(false) {}
-  bool success;
-  bool o1;
-  bool o2;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_drop_type_presult__isset;
 
 class ThriftHiveMetastore_drop_type_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "3499095F5992356B85332339F1B55814";
+  static const uint8_t binary_fingerprint[16]; // = {0x34,0x99,0x09,0x5F,0x59,0x92,0x35,0x6B,0x85,0x33,0x23,0x39,0xF1,0xB5,0x58,0x14};
 
-  virtual ~ThriftHiveMetastore_drop_type_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_drop_type_presult() throw();
   bool* success;
   MetaException o1;
   NoSuchObjectException o2;
@@ -1940,28 +2031,31 @@ class ThriftHiveMetastore_drop_type_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_drop_type_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_all_args__isset {
   _ThriftHiveMetastore_get_type_all_args__isset() : name(false) {}
-  bool name;
+  bool name :1;
 } _ThriftHiveMetastore_get_type_all_args__isset;
 
 class ThriftHiveMetastore_get_type_all_args {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
+
+  ThriftHiveMetastore_get_type_all_args(const ThriftHiveMetastore_get_type_all_args&);
+  ThriftHiveMetastore_get_type_all_args& operator=(const ThriftHiveMetastore_get_type_all_args&);
   ThriftHiveMetastore_get_type_all_args() : name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_type_all_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_type_all_args() throw();
   std::string name;
 
   _ThriftHiveMetastore_get_type_all_args__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_type_all_args & rhs) const
   {
@@ -1978,47 +2072,51 @@ class ThriftHiveMetastore_get_type_all_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_all_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_type_all_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
+  static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
-  virtual ~ThriftHiveMetastore_get_type_all_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_type_all_pargs() throw();
   const std::string* name;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_all_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_all_result__isset {
   _ThriftHiveMetastore_get_type_all_result__isset() : success(false), o2(false) {}
-  bool success;
-  bool o2;
+  bool success :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_type_all_result__isset;
 
 class ThriftHiveMetastore_get_type_all_result {
  public:
 
+  static const char* ascii_fingerprint; // = "4AD9FFB783428C996DEB713D38DA38C4";
+  static const uint8_t binary_fingerprint[16]; // = {0x4A,0xD9,0xFF,0xB7,0x83,0x42,0x8C,0x99,0x6D,0xEB,0x71,0x3D,0x38,0xDA,0x38,0xC4};
+
+  ThriftHiveMetastore_get_type_all_result(const ThriftHiveMetastore_get_type_all_result&);
+  ThriftHiveMetastore_get_type_all_result& operator=(const ThriftHiveMetastore_get_type_all_result&);
   ThriftHiveMetastore_get_type_all_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_type_all_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_type_all_result() throw();
   std::map<std::string, Type>  success;
   MetaException o2;
 
   _ThriftHiveMetastore_get_type_all_result__isset __isset;
 
-  void __set_success(const std::map<std::string, Type> & val) {
-    success = val;
-  }
+  void __set_success(const std::map<std::string, Type> & val);
 
-  void __set_o2(const MetaException& val) {
-    o2 = val;
-  }
+  void __set_o2(const MetaException& val);
 
   bool operator == (const ThriftHiveMetastore_get_type_all_result & rhs) const
   {
@@ -2037,20 +2135,23 @@ class ThriftHiveMetastore_get_type_all_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_all_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_type_all_presult__isset {
   _ThriftHiveMetastore_get_type_all_presult__isset() : success(false), o2(false) {}
-  bool success;
-  bool o2;
+  bool success :1;
+  bool o2 :1;
 } _ThriftHiveMetastore_get_type_all_presult__isset;
 
 class ThriftHiveMetastore_get_type_all_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "4AD9FFB783428C996DEB713D38DA38C4";
+  static const uint8_t binary_fingerprint[16]; // = {0x4A,0xD9,0xFF,0xB7,0x83,0x42,0x8C,0x99,0x6D,0xEB,0x71,0x3D,0x38,0xDA,0x38,0xC4};
 
-  virtual ~ThriftHiveMetastore_get_type_all_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_type_all_presult() throw();
   std::map<std::string, Type> * success;
   MetaException o2;
 
@@ -2058,34 +2159,35 @@ class ThriftHiveMetastore_get_type_all_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_type_all_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_args__isset {
   _ThriftHiveMetastore_get_fields_args__isset() : db_name(false), table_name(false) {}
-  bool db_name;
-  bool table_name;
+  bool db_name :1;
+  bool table_name :1;
 } _ThriftHiveMetastore_get_fields_args__isset;
 
 class ThriftHiveMetastore_get_fields_args {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
+
+  ThriftHiveMetastore_get_fields_args(const ThriftHiveMetastore_get_fields_args&);
+  ThriftHiveMetastore_get_fields_args& operator=(const ThriftHiveMetastore_get_fields_args&);
   ThriftHiveMetastore_get_fields_args() : db_name(), table_name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_fields_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_fields_args() throw();
   std::string db_name;
   std::string table_name;
 
   _ThriftHiveMetastore_get_fields_args__isset __isset;
 
-  void __set_db_name(const std::string& val) {
-    db_name = val;
-  }
+  void __set_db_name(const std::string& val);
 
-  void __set_table_name(const std::string& val) {
-    table_name = val;
-  }
+  void __set_table_name(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_fields_args & rhs) const
   {
@@ -2104,38 +2206,46 @@ class ThriftHiveMetastore_get_fields_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_fields_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
-  virtual ~ThriftHiveMetastore_get_fields_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_fields_pargs() throw();
   const std::string* db_name;
   const std::string* table_name;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_result__isset {
   _ThriftHiveMetastore_get_fields_result__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_fields_result__isset;
 
 class ThriftHiveMetastore_get_fields_result {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
+
+  ThriftHiveMetastore_get_fields_result(const ThriftHiveMetastore_get_fields_result&);
+  ThriftHiveMetastore_get_fields_result& operator=(const ThriftHiveMetastore_get_fields_result&);
   ThriftHiveMetastore_get_fields_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_fields_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_fields_result() throw();
   std::vector<FieldSchema>  success;
   MetaException o1;
   UnknownTableException o2;
@@ -2143,21 +2253,13 @@ class ThriftHiveMetastore_get_fields_result {
 
   _ThriftHiveMetastore_get_fields_result__isset __isset;
 
-  void __set_success(const std::vector<FieldSchema> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<FieldSchema> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const UnknownTableException& val) {
-    o2 = val;
-  }
+  void __set_o2(const UnknownTableException& val);
 
-  void __set_o3(const UnknownDBException& val) {
-    o3 = val;
-  }
+  void __set_o3(const UnknownDBException& val);
 
   bool operator == (const ThriftHiveMetastore_get_fields_result & rhs) const
   {
@@ -2180,22 +2282,25 @@ class ThriftHiveMetastore_get_fields_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_presult__isset {
   _ThriftHiveMetastore_get_fields_presult__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_fields_presult__isset;
 
 class ThriftHiveMetastore_get_fields_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
 
-  virtual ~ThriftHiveMetastore_get_fields_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_fields_presult() throw();
   std::vector<FieldSchema> * success;
   MetaException o1;
   UnknownTableException o2;
@@ -2205,40 +2310,39 @@ class ThriftHiveMetastore_get_fields_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_with_environment_context_args__isset {
   _ThriftHiveMetastore_get_fields_with_environment_context_args__isset() : db_name(false), table_name(false), environment_context(false) {}
-  bool db_name;
-  bool table_name;
-  bool environment_context;
+  bool db_name :1;
+  bool table_name :1;
+  bool environment_context :1;
 } _ThriftHiveMetastore_get_fields_with_environment_context_args__isset;
 
 class ThriftHiveMetastore_get_fields_with_environment_context_args {
  public:
 
+  static const char* ascii_fingerprint; // = "AE0D6195F9A2D9B00B409A0B58C4F0AE";
+  static const uint8_t binary_fingerprint[16]; // = {0xAE,0x0D,0x61,0x95,0xF9,0xA2,0xD9,0xB0,0x0B,0x40,0x9A,0x0B,0x58,0xC4,0xF0,0xAE};
+
+  ThriftHiveMetastore_get_fields_with_environment_context_args(const ThriftHiveMetastore_get_fields_with_environment_context_args&);
+  ThriftHiveMetastore_get_fields_with_environment_context_args& operator=(const ThriftHiveMetastore_get_fields_with_environment_context_args&);
   ThriftHiveMetastore_get_fields_with_environment_context_args() : db_name(), table_name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_args() throw();
   std::string db_name;
   std::string table_name;
   EnvironmentContext environment_context;
 
   _ThriftHiveMetastore_get_fields_with_environment_context_args__isset __isset;
 
-  void __set_db_name(const std::string& val) {
-    db_name = val;
-  }
+  void __set_db_name(const std::string& val);
 
-  void __set_table_name(const std::string& val) {
-    table_name = val;
-  }
+  void __set_table_name(const std::string& val);
 
-  void __set_environment_context(const EnvironmentContext& val) {
-    environment_context = val;
-  }
+  void __set_environment_context(const EnvironmentContext& val);
 
   bool operator == (const ThriftHiveMetastore_get_fields_with_environment_context_args & rhs) const
   {
@@ -2259,39 +2363,47 @@ class ThriftHiveMetastore_get_fields_with_environment_context_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_with_environment_context_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_fields_with_environment_context_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "AE0D6195F9A2D9B00B409A0B58C4F0AE";
+  static const uint8_t binary_fingerprint[16]; // = {0xAE,0x0D,0x61,0x95,0xF9,0xA2,0xD9,0xB0,0x0B,0x40,0x9A,0x0B,0x58,0xC4,0xF0,0xAE};
 
-  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_pargs() throw();
   const std::string* db_name;
   const std::string* table_name;
   const EnvironmentContext* environment_context;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_with_environment_context_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_with_environment_context_result__isset {
   _ThriftHiveMetastore_get_fields_with_environment_context_result__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_fields_with_environment_context_result__isset;
 
 class ThriftHiveMetastore_get_fields_with_environment_context_result {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
+
+  ThriftHiveMetastore_get_fields_with_environment_context_result(const ThriftHiveMetastore_get_fields_with_environment_context_result&);
+  ThriftHiveMetastore_get_fields_with_environment_context_result& operator=(const ThriftHiveMetastore_get_fields_with_environment_context_result&);
   ThriftHiveMetastore_get_fields_with_environment_context_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_result() throw();
   std::vector<FieldSchema>  success;
   MetaException o1;
   UnknownTableException o2;
@@ -2299,21 +2411,13 @@ class ThriftHiveMetastore_get_fields_with_environment_context_result {
 
   _ThriftHiveMetastore_get_fields_with_environment_context_result__isset __isset;
 
-  void __set_success(const std::vector<FieldSchema> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<FieldSchema> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const UnknownTableException& val) {
-    o2 = val;
-  }
+  void __set_o2(const UnknownTableException& val);
 
-  void __set_o3(const UnknownDBException& val) {
-    o3 = val;
-  }
+  void __set_o3(const UnknownDBException& val);
 
   bool operator == (const ThriftHiveMetastore_get_fields_with_environment_context_result & rhs) const
   {
@@ -2336,22 +2440,25 @@ class ThriftHiveMetastore_get_fields_with_environment_context_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_with_environment_context_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_fields_with_environment_context_presult__isset {
   _ThriftHiveMetastore_get_fields_with_environment_context_presult__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_fields_with_environment_context_presult__isset;
 
 class ThriftHiveMetastore_get_fields_with_environment_context_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
 
-  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_fields_with_environment_context_presult() throw();
   std::vector<FieldSchema> * success;
   MetaException o1;
   UnknownTableException o2;
@@ -2361,34 +2468,35 @@ class ThriftHiveMetastore_get_fields_with_environment_context_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_fields_with_environment_context_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_args__isset {
   _ThriftHiveMetastore_get_schema_args__isset() : db_name(false), table_name(false) {}
-  bool db_name;
-  bool table_name;
+  bool db_name :1;
+  bool table_name :1;
 } _ThriftHiveMetastore_get_schema_args__isset;
 
 class ThriftHiveMetastore_get_schema_args {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
+
+  ThriftHiveMetastore_get_schema_args(const ThriftHiveMetastore_get_schema_args&);
+  ThriftHiveMetastore_get_schema_args& operator=(const ThriftHiveMetastore_get_schema_args&);
   ThriftHiveMetastore_get_schema_args() : db_name(), table_name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_schema_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_schema_args() throw();
   std::string db_name;
   std::string table_name;
 
   _ThriftHiveMetastore_get_schema_args__isset __isset;
 
-  void __set_db_name(const std::string& val) {
-    db_name = val;
-  }
+  void __set_db_name(const std::string& val);
 
-  void __set_table_name(const std::string& val) {
-    table_name = val;
-  }
+  void __set_table_name(const std::string& val);
 
   bool operator == (const ThriftHiveMetastore_get_schema_args & rhs) const
   {
@@ -2407,38 +2515,46 @@ class ThriftHiveMetastore_get_schema_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_schema_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
+  static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
-  virtual ~ThriftHiveMetastore_get_schema_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_schema_pargs() throw();
   const std::string* db_name;
   const std::string* table_name;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_result__isset {
   _ThriftHiveMetastore_get_schema_result__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_schema_result__isset;
 
 class ThriftHiveMetastore_get_schema_result {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
+
+  ThriftHiveMetastore_get_schema_result(const ThriftHiveMetastore_get_schema_result&);
+  ThriftHiveMetastore_get_schema_result& operator=(const ThriftHiveMetastore_get_schema_result&);
   ThriftHiveMetastore_get_schema_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_schema_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_schema_result() throw();
   std::vector<FieldSchema>  success;
   MetaException o1;
   UnknownTableException o2;
@@ -2446,21 +2562,13 @@ class ThriftHiveMetastore_get_schema_result {
 
   _ThriftHiveMetastore_get_schema_result__isset __isset;
 
-  void __set_success(const std::vector<FieldSchema> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<FieldSchema> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const UnknownTableException& val) {
-    o2 = val;
-  }
+  void __set_o2(const UnknownTableException& val);
 
-  void __set_o3(const UnknownDBException& val) {
-    o3 = val;
-  }
+  void __set_o3(const UnknownDBException& val);
 
   bool operator == (const ThriftHiveMetastore_get_schema_result & rhs) const
   {
@@ -2483,22 +2591,25 @@ class ThriftHiveMetastore_get_schema_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_presult__isset {
   _ThriftHiveMetastore_get_schema_presult__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_schema_presult__isset;
 
 class ThriftHiveMetastore_get_schema_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
 
-  virtual ~ThriftHiveMetastore_get_schema_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_schema_presult() throw();
   std::vector<FieldSchema> * success;
   MetaException o1;
   UnknownTableException o2;
@@ -2508,40 +2619,39 @@ class ThriftHiveMetastore_get_schema_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_with_environment_context_args__isset {
   _ThriftHiveMetastore_get_schema_with_environment_context_args__isset() : db_name(false), table_name(false), environment_context(false) {}
-  bool db_name;
-  bool table_name;
-  bool environment_context;
+  bool db_name :1;
+  bool table_name :1;
+  bool environment_context :1;
 } _ThriftHiveMetastore_get_schema_with_environment_context_args__isset;
 
 class ThriftHiveMetastore_get_schema_with_environment_context_args {
  public:
 
+  static const char* ascii_fingerprint; // = "AE0D6195F9A2D9B00B409A0B58C4F0AE";
+  static const uint8_t binary_fingerprint[16]; // = {0xAE,0x0D,0x61,0x95,0xF9,0xA2,0xD9,0xB0,0x0B,0x40,0x9A,0x0B,0x58,0xC4,0xF0,0xAE};
+
+  ThriftHiveMetastore_get_schema_with_environment_context_args(const ThriftHiveMetastore_get_schema_with_environment_context_args&);
+  ThriftHiveMetastore_get_schema_with_environment_context_args& operator=(const ThriftHiveMetastore_get_schema_with_environment_context_args&);
   ThriftHiveMetastore_get_schema_with_environment_context_args() : db_name(), table_name() {
   }
 
-  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_args() throw();
   std::string db_name;
   std::string table_name;
   EnvironmentContext environment_context;
 
   _ThriftHiveMetastore_get_schema_with_environment_context_args__isset __isset;
 
-  void __set_db_name(const std::string& val) {
-    db_name = val;
-  }
+  void __set_db_name(const std::string& val);
 
-  void __set_table_name(const std::string& val) {
-    table_name = val;
-  }
+  void __set_table_name(const std::string& val);
 
-  void __set_environment_context(const EnvironmentContext& val) {
-    environment_context = val;
-  }
+  void __set_environment_context(const EnvironmentContext& val);
 
   bool operator == (const ThriftHiveMetastore_get_schema_with_environment_context_args & rhs) const
   {
@@ -2562,39 +2672,47 @@ class ThriftHiveMetastore_get_schema_with_environment_context_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_with_environment_context_args& obj);
 };
 
 
 class ThriftHiveMetastore_get_schema_with_environment_context_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "AE0D6195F9A2D9B00B409A0B58C4F0AE";
+  static const uint8_t binary_fingerprint[16]; // = {0xAE,0x0D,0x61,0x95,0xF9,0xA2,0xD9,0xB0,0x0B,0x40,0x9A,0x0B,0x58,0xC4,0xF0,0xAE};
 
-  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_pargs() throw();
   const std::string* db_name;
   const std::string* table_name;
   const EnvironmentContext* environment_context;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_with_environment_context_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_with_environment_context_result__isset {
   _ThriftHiveMetastore_get_schema_with_environment_context_result__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_schema_with_environment_context_result__isset;
 
 class ThriftHiveMetastore_get_schema_with_environment_context_result {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
+
+  ThriftHiveMetastore_get_schema_with_environment_context_result(const ThriftHiveMetastore_get_schema_with_environment_context_result&);
+  ThriftHiveMetastore_get_schema_with_environment_context_result& operator=(const ThriftHiveMetastore_get_schema_with_environment_context_result&);
   ThriftHiveMetastore_get_schema_with_environment_context_result() {
   }
 
-  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_result() throw();
   std::vector<FieldSchema>  success;
   MetaException o1;
   UnknownTableException o2;
@@ -2602,21 +2720,13 @@ class ThriftHiveMetastore_get_schema_with_environment_context_result {
 
   _ThriftHiveMetastore_get_schema_with_environment_context_result__isset __isset;
 
-  void __set_success(const std::vector<FieldSchema> & val) {
-    success = val;
-  }
+  void __set_success(const std::vector<FieldSchema> & val);
 
-  void __set_o1(const MetaException& val) {
-    o1 = val;
-  }
+  void __set_o1(const MetaException& val);
 
-  void __set_o2(const UnknownTableException& val) {
-    o2 = val;
-  }
+  void __set_o2(const UnknownTableException& val);
 
-  void __set_o3(const UnknownDBException& val) {
-    o3 = val;
-  }
+  void __set_o3(const UnknownDBException& val);
 
   bool operator == (const ThriftHiveMetastore_get_schema_with_environment_context_result & rhs) const
   {
@@ -2639,22 +2749,25 @@ class ThriftHiveMetastore_get_schema_with_environment_context_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_with_environment_context_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_get_schema_with_environment_context_presult__isset {
   _ThriftHiveMetastore_get_schema_with_environment_context_presult__isset() : success(false), o1(false), o2(false), o3(false) {}
-  bool success;
-  bool o1;
-  bool o2;
-  bool o3;
+  bool success :1;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
 } _ThriftHiveMetastore_get_schema_with_environment_context_presult__isset;
 
 class ThriftHiveMetastore_get_schema_with_environment_context_presult {
  public:
 
+  static const char* ascii_fingerprint; // = "B736CA8B9EACE5EE093DF8D460EE0F4E";
+  static const uint8_t binary_fingerprint[16]; // = {0xB7,0x36,0xCA,0x8B,0x9E,0xAC,0xE5,0xEE,0x09,0x3D,0xF8,0xD4,0x60,0xEE,0x0F,0x4E};
 
-  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_presult() throw() {}
 
+  virtual ~ThriftHiveMetastore_get_schema_with_environment_context_presult() throw();
   std::vector<FieldSchema> * success;
   MetaException o1;
   UnknownTableException o2;
@@ -2664,28 +2777,31 @@ class ThriftHiveMetastore_get_schema_with_environment_context_presult {
 
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_get_schema_with_environment_context_presult& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_table_args__isset {
   _ThriftHiveMetastore_create_table_args__isset() : tbl(false) {}
-  bool tbl;
+  bool tbl :1;
 } _ThriftHiveMetastore_create_table_args__isset;
 
 class ThriftHiveMetastore_create_table_args {
  public:
 
+  static const char* ascii_fingerprint; // = "BD1951DCA22A23C9A7B1CD46ACAE54DB";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x19,0x51,0xDC,0xA2,0x2A,0x23,0xC9,0xA7,0xB1,0xCD,0x46,0xAC,0xAE,0x54,0xDB};
+
+  ThriftHiveMetastore_create_table_args(const ThriftHiveMetastore_create_table_args&);
+  ThriftHiveMetastore_create_table_args& operator=(const ThriftHiveMetastore_create_table_args&);
   ThriftHiveMetastore_create_table_args() {
   }
 
-  virtual ~ThriftHiveMetastore_create_table_args() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_table_args() throw();
   Table tbl;
 
   _ThriftHiveMetastore_create_table_args__isset __isset;
 
-  void __set_tbl(const Table& val) {
-    tbl = val;
-  }
+  void __set_tbl(const Table& val);
 
   bool operator == (const ThriftHiveMetastore_create_table_args & rhs) const
   {
@@ -2702,37 +2818,45 @@ class ThriftHiveMetastore_create_table_args {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_table_args& obj);
 };
 
 
 class ThriftHiveMetastore_create_table_pargs {
  public:
 
+  static const char* ascii_fingerprint; // = "BD1951DCA22A23C9A7B1CD46ACAE54DB";
+  static const uint8_t binary_fingerprint[16]; // = {0xBD,0x19,0x51,0xDC,0xA2,0x2A,0x23,0xC9,0xA7,0xB1,0xCD,0x46,0xAC,0xAE,0x54,0xDB};
 
-  virtual ~ThriftHiveMetastore_create_table_pargs() throw() {}
 
+  virtual ~ThriftHiveMetastore_create_table_pargs() throw();
   const Table* tbl;
 
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_table_pargs& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_table_result__isset {
   _ThriftHiveMetastore_create_table_result__isset() : o1(false), o2(false), o3(false), o4(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
-  bool o4;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
+  bool o4 :1;
 } _ThriftHiveMetastore_create_table_result__isset;
 
 class ThriftHiveMetastore_create_table_result {
  public:
 
+  static const char* ascii_fingerprint; // = "F9EF8E19A6AC2C4E08D282524B9828EB";
+  static const uint8_t binary_fingerprint[16]; // = {0xF9,0xEF,0x8E,0x19,0xA6,0xAC,0x2C,0x4E,0x08,0xD2,0x82,0x52,0x4B,0x98,0x28,0xEB};
+
+  ThriftHiveMetastore_create_table_result(const ThriftHiveMetastore_create_table_result&);
+  ThriftHiveMetastore_create_table_result& operator=(const ThriftHiveMetastore_create_table_result&);
   ThriftHiveMetastore_create_table_result() {
   }
 
-  virtual ~ThriftHiveMetastore_create_table_result() throw() {}
-
+  virtual ~ThriftHiveMetastore_create_table_result() throw();
   AlreadyExistsException o1;
   InvalidObjectException o2;
   MetaException o3;
@@ -2740,21 +2864,13 @@ class ThriftHiveMetastore_create_table_result {
 
   _ThriftHiveMetastore_create_table_result__isset __isset;
 
-  void __set_o1(const AlreadyExistsException& val) {
-    o1 = val;
-  }
+  void __set_o1(const AlreadyExistsException& val);
 
-  void __set_o2(const InvalidObjectException& val) {
-    o2 = val;
-  }
+  void __set_o2(const InvalidObjectException& val);
 
-  void __set_o3(const MetaException& val) {
-    o3 = val;
-  }
+  void __set_o3(const MetaException& val);
 
-  void __set_o4(const NoSuchObjectException& val) {
-    o4 = val;
-  }
+  void __set_o4(const NoSuchObjectException& val);
 
   bool operator == (const ThriftHiveMetastore_create_table_result & rhs) const
   {
@@ -2777,22 +2893,25 @@ class ThriftHiveMetastore_create_table_result {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ThriftHiveMetastore_create_table_result& obj);
 };
 
 typedef struct _ThriftHiveMetastore_create_table_presult__isset {
   _ThriftHiveMetastore_create_table_presult__isset() : o1(false), o2(false), o3(false), o4(false) {}
-  bool o1;
-  bool o2;
-  bool o3;
-  bool o4;
+  bool o1 :1;
+  bool o2 :1;
+  bool o3 :1;
+  bool o4 :1;
 } _ThriftHiveMetastore_create_table_presult__isset;
 
 cla

<TRUNCATED>

[02/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-php/ThriftHive.php
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-php/ThriftHive.php b/service/src/gen/thrift/gen-php/ThriftHive.php
index 8fc3ff4..2c783b6 100644
--- a/service/src/gen/thrift/gen-php/ThriftHive.php
+++ b/service/src/gen/thrift/gen-php/ThriftHive.php
@@ -1,7 +1,7 @@
 <?php
 namespace ;
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,18 +12,54 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
 interface ThriftHiveIf extends \metastore\ThriftHiveMetastoreIf {
+  /**
+   * @param string $query
+   * @throws \HiveServerException
+   */
   public function execute($query);
+  /**
+   * @return string
+   * @throws \HiveServerException
+   */
   public function fetchOne();
+  /**
+   * @param int $numRows
+   * @return string[]
+   * @throws \HiveServerException
+   */
   public function fetchN($numRows);
+  /**
+   * @return string[]
+   * @throws \HiveServerException
+   */
   public function fetchAll();
+  /**
+   * @return \metastore\Schema
+   * @throws \HiveServerException
+   */
   public function getSchema();
+  /**
+   * @return \metastore\Schema
+   * @throws \HiveServerException
+   */
   public function getThriftSchema();
+  /**
+   * @return \HiveClusterStatus
+   * @throws \HiveServerException
+   */
   public function getClusterStatus();
+  /**
+   * @return \QueryPlan
+   * @throws \HiveServerException
+   */
   public function getQueryPlan();
+  /**
+   */
   public function clean();
 }
 
@@ -42,7 +78,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   {
     $args = new \ThriftHive_execute_args();
     $args->query = $query;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'execute', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -58,7 +94,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_execute()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_execute_result', $this->input_->isStrictRead());
     else
     {
@@ -92,7 +128,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_fetchOne()
   {
     $args = new \ThriftHive_fetchOne_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'fetchOne', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -108,7 +144,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_fetchOne()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_fetchOne_result', $this->input_->isStrictRead());
     else
     {
@@ -146,7 +182,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   {
     $args = new \ThriftHive_fetchN_args();
     $args->numRows = $numRows;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'fetchN', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -162,7 +198,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_fetchN()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_fetchN_result', $this->input_->isStrictRead());
     else
     {
@@ -199,7 +235,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_fetchAll()
   {
     $args = new \ThriftHive_fetchAll_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'fetchAll', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -215,7 +251,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_fetchAll()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_fetchAll_result', $this->input_->isStrictRead());
     else
     {
@@ -252,7 +288,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_getSchema()
   {
     $args = new \ThriftHive_getSchema_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'getSchema', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -268,7 +304,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_getSchema()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_getSchema_result', $this->input_->isStrictRead());
     else
     {
@@ -305,7 +341,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_getThriftSchema()
   {
     $args = new \ThriftHive_getThriftSchema_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'getThriftSchema', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -321,7 +357,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_getThriftSchema()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_getThriftSchema_result', $this->input_->isStrictRead());
     else
     {
@@ -358,7 +394,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_getClusterStatus()
   {
     $args = new \ThriftHive_getClusterStatus_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'getClusterStatus', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -374,7 +410,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_getClusterStatus()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_getClusterStatus_result', $this->input_->isStrictRead());
     else
     {
@@ -411,7 +447,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_getQueryPlan()
   {
     $args = new \ThriftHive_getQueryPlan_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'getQueryPlan', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -427,7 +463,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_getQueryPlan()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_getQueryPlan_result', $this->input_->isStrictRead());
     else
     {
@@ -464,7 +500,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
   public function send_clean()
   {
     $args = new \ThriftHive_clean_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'clean', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -480,7 +516,7 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 
   public function recv_clean()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\ThriftHive_clean_result', $this->input_->isStrictRead());
     else
     {
@@ -509,6 +545,9 @@ class ThriftHiveClient extends \metastore\ThriftHiveMetastoreClient implements \
 class ThriftHive_execute_args {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $query = null;
 
   public function __construct($vals=null) {
@@ -581,6 +620,9 @@ class ThriftHive_execute_args {
 class ThriftHive_execute_result {
   static $_TSPEC;
 
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -705,7 +747,13 @@ class ThriftHive_fetchOne_args {
 class ThriftHive_fetchOne_result {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -799,6 +847,9 @@ class ThriftHive_fetchOne_result {
 class ThriftHive_fetchN_args {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $numRows = null;
 
   public function __construct($vals=null) {
@@ -871,7 +922,13 @@ class ThriftHive_fetchN_args {
 class ThriftHive_fetchN_result {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -1041,7 +1098,13 @@ class ThriftHive_fetchAll_args {
 class ThriftHive_fetchAll_result {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -1211,7 +1274,13 @@ class ThriftHive_getSchema_args {
 class ThriftHive_getSchema_result {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Schema
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -1360,7 +1429,13 @@ class ThriftHive_getThriftSchema_args {
 class ThriftHive_getThriftSchema_result {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Schema
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -1509,7 +1584,13 @@ class ThriftHive_getClusterStatus_args {
 class ThriftHive_getClusterStatus_result {
   static $_TSPEC;
 
+  /**
+   * @var \HiveClusterStatus
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {
@@ -1658,7 +1739,13 @@ class ThriftHive_getQueryPlan_args {
 class ThriftHive_getQueryPlan_result {
   static $_TSPEC;
 
+  /**
+   * @var \QueryPlan
+   */
   public $success = null;
+  /**
+   * @var \HiveServerException
+   */
   public $ex = null;
 
   public function __construct($vals=null) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-php/Types.php
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-php/Types.php b/service/src/gen/thrift/gen-php/Types.php
index f4225ad..d8f3c5b 100644
--- a/service/src/gen/thrift/gen-php/Types.php
+++ b/service/src/gen/thrift/gen-php/Types.php
@@ -2,7 +2,7 @@
 namespace ;
 
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -13,6 +13,7 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
@@ -28,11 +29,29 @@ final class JobTrackerState {
 class HiveClusterStatus {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $taskTrackers = null;
+  /**
+   * @var int
+   */
   public $mapTasks = null;
+  /**
+   * @var int
+   */
   public $reduceTasks = null;
+  /**
+   * @var int
+   */
   public $maxMapTasks = null;
+  /**
+   * @var int
+   */
   public $maxReduceTasks = null;
+  /**
+   * @var int
+   */
   public $state = null;
 
   public function __construct($vals=null) {
@@ -200,8 +219,17 @@ class HiveClusterStatus {
 class HiveServerException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
+  /**
+   * @var int
+   */
   public $errorCode = null;
+  /**
+   * @var string
+   */
   public $SQLState = null;
 
   public function __construct($vals=null) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/TCLIService/TCLIService-remote
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/TCLIService/TCLIService-remote b/service/src/gen/thrift/gen-py/TCLIService/TCLIService-remote
old mode 100644
new mode 100755
index f6ff43f..2bfca56
--- a/service/src/gen/thrift/gen-py/TCLIService/TCLIService-remote
+++ b/service/src/gen/thrift/gen-py/TCLIService/TCLIService-remote
@@ -1,6 +1,6 @@
 #!/usr/bin/env python
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -12,37 +12,38 @@ import pprint
 from urlparse import urlparse
 from thrift.transport import TTransport
 from thrift.transport import TSocket
+from thrift.transport import TSSLSocket
 from thrift.transport import THttpClient
 from thrift.protocol import TBinaryProtocol
 
-import TCLIService
-from ttypes import *
+from TCLIService import TCLIService
+from TCLIService.ttypes import *
 
 if len(sys.argv) <= 1 or sys.argv[1] == '--help':
-  print ''
-  print 'Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] function [arg1 [arg2...]]'
-  print ''
-  print 'Functions:'
-  print '  TOpenSessionResp OpenSession(TOpenSessionReq req)'
-  print '  TCloseSessionResp CloseSession(TCloseSessionReq req)'
-  print '  TGetInfoResp GetInfo(TGetInfoReq req)'
-  print '  TExecuteStatementResp ExecuteStatement(TExecuteStatementReq req)'
-  print '  TGetTypeInfoResp GetTypeInfo(TGetTypeInfoReq req)'
-  print '  TGetCatalogsResp GetCatalogs(TGetCatalogsReq req)'
-  print '  TGetSchemasResp GetSchemas(TGetSchemasReq req)'
-  print '  TGetTablesResp GetTables(TGetTablesReq req)'
-  print '  TGetTableTypesResp GetTableTypes(TGetTableTypesReq req)'
-  print '  TGetColumnsResp GetColumns(TGetColumnsReq req)'
-  print '  TGetFunctionsResp GetFunctions(TGetFunctionsReq req)'
-  print '  TGetOperationStatusResp GetOperationStatus(TGetOperationStatusReq req)'
-  print '  TCancelOperationResp CancelOperation(TCancelOperationReq req)'
-  print '  TCloseOperationResp CloseOperation(TCloseOperationReq req)'
-  print '  TGetResultSetMetadataResp GetResultSetMetadata(TGetResultSetMetadataReq req)'
-  print '  TFetchResultsResp FetchResults(TFetchResultsReq req)'
-  print '  TGetDelegationTokenResp GetDelegationToken(TGetDelegationTokenReq req)'
-  print '  TCancelDelegationTokenResp CancelDelegationToken(TCancelDelegationTokenReq req)'
-  print '  TRenewDelegationTokenResp RenewDelegationToken(TRenewDelegationTokenReq req)'
-  print ''
+  print('')
+  print('Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] [-s[sl]] function [arg1 [arg2...]]')
+  print('')
+  print('Functions:')
+  print('  TOpenSessionResp OpenSession(TOpenSessionReq req)')
+  print('  TCloseSessionResp CloseSession(TCloseSessionReq req)')
+  print('  TGetInfoResp GetInfo(TGetInfoReq req)')
+  print('  TExecuteStatementResp ExecuteStatement(TExecuteStatementReq req)')
+  print('  TGetTypeInfoResp GetTypeInfo(TGetTypeInfoReq req)')
+  print('  TGetCatalogsResp GetCatalogs(TGetCatalogsReq req)')
+  print('  TGetSchemasResp GetSchemas(TGetSchemasReq req)')
+  print('  TGetTablesResp GetTables(TGetTablesReq req)')
+  print('  TGetTableTypesResp GetTableTypes(TGetTableTypesReq req)')
+  print('  TGetColumnsResp GetColumns(TGetColumnsReq req)')
+  print('  TGetFunctionsResp GetFunctions(TGetFunctionsReq req)')
+  print('  TGetOperationStatusResp GetOperationStatus(TGetOperationStatusReq req)')
+  print('  TCancelOperationResp CancelOperation(TCancelOperationReq req)')
+  print('  TCloseOperationResp CloseOperation(TCloseOperationReq req)')
+  print('  TGetResultSetMetadataResp GetResultSetMetadata(TGetResultSetMetadataReq req)')
+  print('  TFetchResultsResp FetchResults(TFetchResultsReq req)')
+  print('  TGetDelegationTokenResp GetDelegationToken(TGetDelegationTokenReq req)')
+  print('  TCancelDelegationTokenResp CancelDelegationToken(TCancelDelegationTokenReq req)')
+  print('  TRenewDelegationTokenResp RenewDelegationToken(TRenewDelegationTokenReq req)')
+  print('')
   sys.exit(0)
 
 pp = pprint.PrettyPrinter(indent = 2)
@@ -50,6 +51,7 @@ host = 'localhost'
 port = 9090
 uri = ''
 framed = False
+ssl = False
 http = False
 argi = 1
 
@@ -78,13 +80,17 @@ if sys.argv[argi] == '-f' or sys.argv[argi] == '-framed':
   framed = True
   argi += 1
 
+if sys.argv[argi] == '-s' or sys.argv[argi] == '-ssl':
+  ssl = True
+  argi += 1
+
 cmd = sys.argv[argi]
 args = sys.argv[argi+1:]
 
 if http:
   transport = THttpClient.THttpClient(host, port, uri)
 else:
-  socket = TSocket.TSocket(host, port)
+  socket = TSSLSocket.TSSLSocket(host, port, validate=False) if ssl else TSocket.TSocket(host, port)
   if framed:
     transport = TTransport.TFramedTransport(socket)
   else:
@@ -95,120 +101,120 @@ transport.open()
 
 if cmd == 'OpenSession':
   if len(args) != 1:
-    print 'OpenSession requires 1 args'
+    print('OpenSession requires 1 args')
     sys.exit(1)
   pp.pprint(client.OpenSession(eval(args[0]),))
 
 elif cmd == 'CloseSession':
   if len(args) != 1:
-    print 'CloseSession requires 1 args'
+    print('CloseSession requires 1 args')
     sys.exit(1)
   pp.pprint(client.CloseSession(eval(args[0]),))
 
 elif cmd == 'GetInfo':
   if len(args) != 1:
-    print 'GetInfo requires 1 args'
+    print('GetInfo requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetInfo(eval(args[0]),))
 
 elif cmd == 'ExecuteStatement':
   if len(args) != 1:
-    print 'ExecuteStatement requires 1 args'
+    print('ExecuteStatement requires 1 args')
     sys.exit(1)
   pp.pprint(client.ExecuteStatement(eval(args[0]),))
 
 elif cmd == 'GetTypeInfo':
   if len(args) != 1:
-    print 'GetTypeInfo requires 1 args'
+    print('GetTypeInfo requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetTypeInfo(eval(args[0]),))
 
 elif cmd == 'GetCatalogs':
   if len(args) != 1:
-    print 'GetCatalogs requires 1 args'
+    print('GetCatalogs requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetCatalogs(eval(args[0]),))
 
 elif cmd == 'GetSchemas':
   if len(args) != 1:
-    print 'GetSchemas requires 1 args'
+    print('GetSchemas requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetSchemas(eval(args[0]),))
 
 elif cmd == 'GetTables':
   if len(args) != 1:
-    print 'GetTables requires 1 args'
+    print('GetTables requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetTables(eval(args[0]),))
 
 elif cmd == 'GetTableTypes':
   if len(args) != 1:
-    print 'GetTableTypes requires 1 args'
+    print('GetTableTypes requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetTableTypes(eval(args[0]),))
 
 elif cmd == 'GetColumns':
   if len(args) != 1:
-    print 'GetColumns requires 1 args'
+    print('GetColumns requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetColumns(eval(args[0]),))
 
 elif cmd == 'GetFunctions':
   if len(args) != 1:
-    print 'GetFunctions requires 1 args'
+    print('GetFunctions requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetFunctions(eval(args[0]),))
 
 elif cmd == 'GetOperationStatus':
   if len(args) != 1:
-    print 'GetOperationStatus requires 1 args'
+    print('GetOperationStatus requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetOperationStatus(eval(args[0]),))
 
 elif cmd == 'CancelOperation':
   if len(args) != 1:
-    print 'CancelOperation requires 1 args'
+    print('CancelOperation requires 1 args')
     sys.exit(1)
   pp.pprint(client.CancelOperation(eval(args[0]),))
 
 elif cmd == 'CloseOperation':
   if len(args) != 1:
-    print 'CloseOperation requires 1 args'
+    print('CloseOperation requires 1 args')
     sys.exit(1)
   pp.pprint(client.CloseOperation(eval(args[0]),))
 
 elif cmd == 'GetResultSetMetadata':
   if len(args) != 1:
-    print 'GetResultSetMetadata requires 1 args'
+    print('GetResultSetMetadata requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetResultSetMetadata(eval(args[0]),))
 
 elif cmd == 'FetchResults':
   if len(args) != 1:
-    print 'FetchResults requires 1 args'
+    print('FetchResults requires 1 args')
     sys.exit(1)
   pp.pprint(client.FetchResults(eval(args[0]),))
 
 elif cmd == 'GetDelegationToken':
   if len(args) != 1:
-    print 'GetDelegationToken requires 1 args'
+    print('GetDelegationToken requires 1 args')
     sys.exit(1)
   pp.pprint(client.GetDelegationToken(eval(args[0]),))
 
 elif cmd == 'CancelDelegationToken':
   if len(args) != 1:
-    print 'CancelDelegationToken requires 1 args'
+    print('CancelDelegationToken requires 1 args')
     sys.exit(1)
   pp.pprint(client.CancelDelegationToken(eval(args[0]),))
 
 elif cmd == 'RenewDelegationToken':
   if len(args) != 1:
-    print 'RenewDelegationToken requires 1 args'
+    print('RenewDelegationToken requires 1 args')
     sys.exit(1)
   pp.pprint(client.RenewDelegationToken(eval(args[0]),))
 
 else:
-  print 'Unrecognized method %s' % cmd
+  print('Unrecognized method %s' % cmd)
   sys.exit(1)
 
 transport.close()

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/TCLIService/TCLIService.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/TCLIService/TCLIService.py b/service/src/gen/thrift/gen-py/TCLIService/TCLIService.py
index ebc6574..0067195 100644
--- a/service/src/gen/thrift/gen-py/TCLIService/TCLIService.py
+++ b/service/src/gen/thrift/gen-py/TCLIService/TCLIService.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -175,16 +175,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_OpenSession(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_OpenSession(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = OpenSession_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "OpenSession failed: unknown result");
@@ -205,16 +206,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_CloseSession(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_CloseSession(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = CloseSession_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "CloseSession failed: unknown result");
@@ -235,16 +237,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetInfo(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetInfo(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetInfo_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetInfo failed: unknown result");
@@ -265,16 +268,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_ExecuteStatement(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_ExecuteStatement(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = ExecuteStatement_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "ExecuteStatement failed: unknown result");
@@ -295,16 +299,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetTypeInfo(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetTypeInfo(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetTypeInfo_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetTypeInfo failed: unknown result");
@@ -325,16 +330,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetCatalogs(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetCatalogs(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetCatalogs_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetCatalogs failed: unknown result");
@@ -355,16 +361,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetSchemas(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetSchemas(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetSchemas_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetSchemas failed: unknown result");
@@ -385,16 +392,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetTables(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetTables(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetTables_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetTables failed: unknown result");
@@ -415,16 +423,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetTableTypes(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetTableTypes(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetTableTypes_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetTableTypes failed: unknown result");
@@ -445,16 +454,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetColumns(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetColumns(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetColumns_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetColumns failed: unknown result");
@@ -475,16 +485,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetFunctions(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetFunctions(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetFunctions_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetFunctions failed: unknown result");
@@ -505,16 +516,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetOperationStatus(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetOperationStatus(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetOperationStatus_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetOperationStatus failed: unknown result");
@@ -535,16 +547,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_CancelOperation(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_CancelOperation(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = CancelOperation_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "CancelOperation failed: unknown result");
@@ -565,16 +578,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_CloseOperation(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_CloseOperation(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = CloseOperation_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "CloseOperation failed: unknown result");
@@ -595,16 +609,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetResultSetMetadata(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetResultSetMetadata(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetResultSetMetadata_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetResultSetMetadata failed: unknown result");
@@ -625,16 +640,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_FetchResults(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_FetchResults(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = FetchResults_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "FetchResults failed: unknown result");
@@ -655,16 +671,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_GetDelegationToken(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_GetDelegationToken(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = GetDelegationToken_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "GetDelegationToken failed: unknown result");
@@ -685,16 +702,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_CancelDelegationToken(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_CancelDelegationToken(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = CancelDelegationToken_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "CancelDelegationToken failed: unknown result");
@@ -715,16 +733,17 @@ class Client(Iface):
     self._oprot.writeMessageEnd()
     self._oprot.trans.flush()
 
-  def recv_RenewDelegationToken(self, ):
-    (fname, mtype, rseqid) = self._iprot.readMessageBegin()
+  def recv_RenewDelegationToken(self):
+    iprot = self._iprot
+    (fname, mtype, rseqid) = iprot.readMessageBegin()
     if mtype == TMessageType.EXCEPTION:
       x = TApplicationException()
-      x.read(self._iprot)
-      self._iprot.readMessageEnd()
+      x.read(iprot)
+      iprot.readMessageEnd()
       raise x
     result = RenewDelegationToken_result()
-    result.read(self._iprot)
-    self._iprot.readMessageEnd()
+    result.read(iprot)
+    iprot.readMessageEnd()
     if result.success is not None:
       return result.success
     raise TApplicationException(TApplicationException.MISSING_RESULT, "RenewDelegationToken failed: unknown result");
@@ -1031,6 +1050,11 @@ class OpenSession_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1091,6 +1115,11 @@ class OpenSession_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1152,6 +1181,11 @@ class CloseSession_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1212,6 +1246,11 @@ class CloseSession_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1273,6 +1312,11 @@ class GetInfo_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1333,6 +1377,11 @@ class GetInfo_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1394,6 +1443,11 @@ class ExecuteStatement_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1454,6 +1508,11 @@ class ExecuteStatement_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1515,6 +1574,11 @@ class GetTypeInfo_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1575,6 +1639,11 @@ class GetTypeInfo_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1636,6 +1705,11 @@ class GetCatalogs_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1696,6 +1770,11 @@ class GetCatalogs_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1757,6 +1836,11 @@ class GetSchemas_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1817,6 +1901,11 @@ class GetSchemas_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1878,6 +1967,11 @@ class GetTables_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1938,6 +2032,11 @@ class GetTables_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1999,6 +2098,11 @@ class GetTableTypes_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2059,6 +2163,11 @@ class GetTableTypes_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2120,6 +2229,11 @@ class GetColumns_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2180,6 +2294,11 @@ class GetColumns_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2241,6 +2360,11 @@ class GetFunctions_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2301,6 +2425,11 @@ class GetFunctions_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2362,6 +2491,11 @@ class GetOperationStatus_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2422,6 +2556,11 @@ class GetOperationStatus_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2483,6 +2622,11 @@ class CancelOperation_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2543,6 +2687,11 @@ class CancelOperation_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2604,6 +2753,11 @@ class CloseOperation_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2664,6 +2818,11 @@ class CloseOperation_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2725,6 +2884,11 @@ class GetResultSetMetadata_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2785,6 +2949,11 @@ class GetResultSetMetadata_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2846,6 +3015,11 @@ class FetchResults_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2906,6 +3080,11 @@ class FetchResults_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2967,6 +3146,11 @@ class GetDelegationToken_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3027,6 +3211,11 @@ class GetDelegationToken_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3088,6 +3277,11 @@ class CancelDelegationToken_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3148,6 +3342,11 @@ class CancelDelegationToken_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3209,6 +3408,11 @@ class RenewDelegationToken_args:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.req)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3269,6 +3473,11 @@ class RenewDelegationToken_result:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/TCLIService/constants.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/TCLIService/constants.py b/service/src/gen/thrift/gen-py/TCLIService/constants.py
index eafcb05..9fb1a86 100644
--- a/service/src/gen/thrift/gen-py/TCLIService/constants.py
+++ b/service/src/gen/thrift/gen-py/TCLIService/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-py/TCLIService/ttypes.py
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-py/TCLIService/ttypes.py b/service/src/gen/thrift/gen-py/TCLIService/ttypes.py
index 068727c..efee8ef 100644
--- a/service/src/gen/thrift/gen-py/TCLIService/ttypes.py
+++ b/service/src/gen/thrift/gen-py/TCLIService/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -449,6 +449,12 @@ class TTypeQualifierValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.i32Value)
+    value = (value * 31) ^ hash(self.stringValue)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -486,7 +492,7 @@ class TTypeQualifiers:
       if fid == 1:
         if ftype == TType.MAP:
           self.qualifiers = {}
-          (_ktype1, _vtype2, _size0 ) = iprot.readMapBegin() 
+          (_ktype1, _vtype2, _size0 ) = iprot.readMapBegin()
           for _i4 in xrange(_size0):
             _key5 = iprot.readString();
             _val6 = TTypeQualifierValue()
@@ -522,6 +528,11 @@ class TTypeQualifiers:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.qualifiers)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -597,6 +608,12 @@ class TPrimitiveTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.typeQualifiers)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -659,6 +676,11 @@ class TArrayTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.objectTypePtr)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -735,6 +757,12 @@ class TMapTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.keyTypePtr)
+    value = (value * 31) ^ hash(self.valueTypePtr)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -772,7 +800,7 @@ class TStructTypeEntry:
       if fid == 1:
         if ftype == TType.MAP:
           self.nameToTypePtr = {}
-          (_ktype10, _vtype11, _size9 ) = iprot.readMapBegin() 
+          (_ktype10, _vtype11, _size9 ) = iprot.readMapBegin()
           for _i13 in xrange(_size9):
             _key14 = iprot.readString();
             _val15 = iprot.readI32();
@@ -807,6 +835,11 @@ class TStructTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.nameToTypePtr)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -844,7 +877,7 @@ class TUnionTypeEntry:
       if fid == 1:
         if ftype == TType.MAP:
           self.nameToTypePtr = {}
-          (_ktype19, _vtype20, _size18 ) = iprot.readMapBegin() 
+          (_ktype19, _vtype20, _size18 ) = iprot.readMapBegin()
           for _i22 in xrange(_size18):
             _key23 = iprot.readString();
             _val24 = iprot.readI32();
@@ -879,6 +912,11 @@ class TUnionTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.nameToTypePtr)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -941,6 +979,11 @@ class TUserDefinedTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.typeClassName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1067,6 +1110,16 @@ class TTypeEntry:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.primitiveEntry)
+    value = (value * 31) ^ hash(self.arrayEntry)
+    value = (value * 31) ^ hash(self.mapEntry)
+    value = (value * 31) ^ hash(self.structEntry)
+    value = (value * 31) ^ hash(self.unionEntry)
+    value = (value * 31) ^ hash(self.userDefinedTypeEntry)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1138,6 +1191,11 @@ class TTypeDesc:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.types)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1241,6 +1299,14 @@ class TColumnDesc:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.columnName)
+    value = (value * 31) ^ hash(self.typeDesc)
+    value = (value * 31) ^ hash(self.position)
+    value = (value * 31) ^ hash(self.comment)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1312,6 +1378,11 @@ class TTableSchema:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.columns)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1372,6 +1443,11 @@ class TBoolValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1432,6 +1508,11 @@ class TByteValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1492,6 +1573,11 @@ class TI16Value:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1552,6 +1638,11 @@ class TI32Value:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1612,6 +1703,11 @@ class TI64Value:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1672,6 +1768,11 @@ class TDoubleValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1732,6 +1833,11 @@ class TStringValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.value)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1871,6 +1977,17 @@ class TColumnValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.boolVal)
+    value = (value * 31) ^ hash(self.byteVal)
+    value = (value * 31) ^ hash(self.i16Val)
+    value = (value * 31) ^ hash(self.i32Val)
+    value = (value * 31) ^ hash(self.i64Val)
+    value = (value * 31) ^ hash(self.doubleVal)
+    value = (value * 31) ^ hash(self.stringVal)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1942,6 +2059,11 @@ class TRow:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.colVals)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2026,6 +2148,12 @@ class TBoolColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2110,6 +2238,12 @@ class TByteColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2194,6 +2328,12 @@ class TI16Column:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2278,6 +2418,12 @@ class TI32Column:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2362,6 +2508,12 @@ class TI64Column:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2446,6 +2598,12 @@ class TDoubleColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2530,6 +2688,12 @@ class TStringColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2614,6 +2778,12 @@ class TBinaryColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.nulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2766,6 +2936,18 @@ class TColumn:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.boolVal)
+    value = (value * 31) ^ hash(self.byteVal)
+    value = (value * 31) ^ hash(self.i16Val)
+    value = (value * 31) ^ hash(self.i32Val)
+    value = (value * 31) ^ hash(self.i64Val)
+    value = (value * 31) ^ hash(self.doubleVal)
+    value = (value * 31) ^ hash(self.stringVal)
+    value = (value * 31) ^ hash(self.binaryVal)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2872,6 +3054,13 @@ class TRowSet:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.startRowOffset)
+    value = (value * 31) ^ hash(self.rows)
+    value = (value * 31) ^ hash(self.columns)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2990,6 +3179,15 @@ class TStatus:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.statusCode)
+    value = (value * 31) ^ hash(self.infoMessages)
+    value = (value * 31) ^ hash(self.sqlState)
+    value = (value * 31) ^ hash(self.errorCode)
+    value = (value * 31) ^ hash(self.errorMessage)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3066,6 +3264,12 @@ class THandleIdentifier:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.guid)
+    value = (value * 31) ^ hash(self.secret)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3129,6 +3333,11 @@ class TSessionHandle:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionId)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3232,6 +3441,14 @@ class TOperationHandle:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationId)
+    value = (value * 31) ^ hash(self.operationType)
+    value = (value * 31) ^ hash(self.hasResultSet)
+    value = (value * 31) ^ hash(self.modifiedRowCount)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3293,7 +3510,7 @@ class TOpenSessionReq:
       elif fid == 4:
         if ftype == TType.MAP:
           self.configuration = {}
-          (_ktype126, _vtype127, _size125 ) = iprot.readMapBegin() 
+          (_ktype126, _vtype127, _size125 ) = iprot.readMapBegin()
           for _i129 in xrange(_size125):
             _key130 = iprot.readString();
             _val131 = iprot.readString();
@@ -3340,6 +3557,14 @@ class TOpenSessionReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.client_protocol)
+    value = (value * 31) ^ hash(self.username)
+    value = (value * 31) ^ hash(self.password)
+    value = (value * 31) ^ hash(self.configuration)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3403,7 +3628,7 @@ class TOpenSessionResp:
       elif fid == 4:
         if ftype == TType.MAP:
           self.configuration = {}
-          (_ktype135, _vtype136, _size134 ) = iprot.readMapBegin() 
+          (_ktype135, _vtype136, _size134 ) = iprot.readMapBegin()
           for _i138 in xrange(_size134):
             _key139 = iprot.readString();
             _val140 = iprot.readString();
@@ -3452,6 +3677,14 @@ class TOpenSessionResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.serverProtocolVersion)
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.configuration)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3515,6 +3748,11 @@ class TCloseSessionReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3578,6 +3816,11 @@ class TCloseSessionResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3698,6 +3941,16 @@ class TGetInfoValue:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.stringValue)
+    value = (value * 31) ^ hash(self.smallIntValue)
+    value = (value * 31) ^ hash(self.integerBitmask)
+    value = (value * 31) ^ hash(self.integerFlag)
+    value = (value * 31) ^ hash(self.binaryValue)
+    value = (value * 31) ^ hash(self.lenValue)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3775,6 +4028,12 @@ class TGetInfoReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.infoType)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3853,6 +4112,12 @@ class TGetInfoResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.infoValue)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3910,7 +4175,7 @@ class TExecuteStatementReq:
       elif fid == 3:
         if ftype == TType.MAP:
           self.confOverlay = {}
-          (_ktype144, _vtype145, _size143 ) = iprot.readMapBegin() 
+          (_ktype144, _vtype145, _size143 ) = iprot.readMapBegin()
           for _i147 in xrange(_size143):
             _key148 = iprot.readString();
             _val149 = iprot.readString();
@@ -3964,6 +4229,14 @@ class TExecuteStatementReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.statement)
+    value = (value * 31) ^ hash(self.confOverlay)
+    value = (value * 31) ^ hash(self.runAsync)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4040,6 +4313,12 @@ class TExecuteStatementResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4103,6 +4382,11 @@ class TGetTypeInfoReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4179,6 +4463,12 @@ class TGetTypeInfoResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4242,6 +4532,11 @@ class TGetCatalogsReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4318,6 +4613,12 @@ class TGetCatalogsResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4405,6 +4706,13 @@ class TGetSchemasReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.catalogName)
+    value = (value * 31) ^ hash(self.schemaName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4481,6 +4789,12 @@ class TGetSchemasResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4600,6 +4914,15 @@ class TGetTablesReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.catalogName)
+    value = (value * 31) ^ hash(self.schemaName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.tableTypes)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4676,6 +4999,12 @@ class TGetTablesResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4739,6 +5068,11 @@ class TGetTableTypesReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4815,6 +5149,12 @@ class TGetTableTypesResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4926,6 +5266,15 @@ class TGetColumnsReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.catalogName)
+    value = (value * 31) ^ hash(self.schemaName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.columnName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5002,6 +5351,12 @@ class TGetColumnsResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5103,6 +5458,14 @@ class TGetFunctionsReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.catalogName)
+    value = (value * 31) ^ hash(self.schemaName)
+    value = (value * 31) ^ hash(self.functionName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5179,6 +5542,12 @@ class TGetFunctionsResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5242,6 +5611,11 @@ class TGetOperationStatusReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5353,6 +5727,15 @@ class TGetOperationStatusResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.operationState)
+    value = (value * 31) ^ hash(self.sqlState)
+    value = (value * 31) ^ hash(self.errorCode)
+    value = (value * 31) ^ hash(self.errorMessage)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5416,6 +5799,11 @@ class TCancelOperationReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5479,6 +5867,11 @@ class TCancelOperationResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5542,6 +5935,11 @@ class TCloseOperationReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5605,6 +6003,11 @@ class TCloseOperationResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5668,6 +6071,11 @@ class TGetResultSetMetadataReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationHandle)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5744,6 +6152,12 @@ class TGetResultSetMetadataResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.schema)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5847,6 +6261,14 @@ class TFetchResultsReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operationHandle)
+    value = (value * 31) ^ hash(self.orientation)
+    value = (value * 31) ^ hash(self.maxRows)
+    value = (value * 31) ^ hash(self.fetchType)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5935,6 +6357,13 @@ class TFetchResultsResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.hasMoreRows)
+    value = (value * 31) ^ hash(self.results)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6026,6 +6455,13 @@ class TGetDelegationTokenReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.owner)
+    value = (value * 31) ^ hash(self.renewer)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6101,6 +6537,12 @@ class TGetDelegationTokenResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    value = (value * 31) ^ hash(self.delegationToken)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6178,6 +6620,12 @@ class TCancelDelegationTokenReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.delegationToken)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6241,6 +6689,11 @@ class TCancelDelegationTokenResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6318,6 +6771,12 @@ class TRenewDelegationTokenReq:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sessionHandle)
+    value = (value * 31) ^ hash(self.delegationToken)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6381,6 +6840,11 @@ class TRenewDelegationTokenResp:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.status)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]


[40/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EnvironmentContext.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EnvironmentContext.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EnvironmentContext.java
index ab0b399..6864c01 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EnvironmentContext.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EnvironmentContext.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentContext, EnvironmentContext._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentContext, EnvironmentContext._Fields>, java.io.Serializable, Cloneable, Comparable<EnvironmentContext> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("EnvironmentContext");
 
   private static final org.apache.thrift.protocol.TField PROPERTIES_FIELD_DESC = new org.apache.thrift.protocol.TField("properties", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -129,18 +133,7 @@ public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentCo
    */
   public EnvironmentContext(EnvironmentContext other) {
     if (other.isSetProperties()) {
-      Map<String,String> __this__properties = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.properties.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__properties_copy_key = other_element_key;
-
-        String __this__properties_copy_value = other_element_value;
-
-        __this__properties.put(__this__properties_copy_key, __this__properties_copy_value);
-      }
+      Map<String,String> __this__properties = new HashMap<String,String>(other.properties);
       this.properties = __this__properties;
     }
   }
@@ -250,30 +243,30 @@ public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentCo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_properties = true && (isSetProperties());
-    builder.append(present_properties);
+    list.add(present_properties);
     if (present_properties)
-      builder.append(properties);
+      list.add(properties);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(EnvironmentContext other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    EnvironmentContext typedOther = (EnvironmentContext)other;
 
-    lastComparison = Boolean.valueOf(isSetProperties()).compareTo(typedOther.isSetProperties());
+    lastComparison = Boolean.valueOf(isSetProperties()).compareTo(other.isSetProperties());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetProperties()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.properties, typedOther.properties);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.properties, other.properties);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -353,13 +346,13 @@ public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentCo
               {
                 org.apache.thrift.protocol.TMap _map312 = iprot.readMapBegin();
                 struct.properties = new HashMap<String,String>(2*_map312.size);
-                for (int _i313 = 0; _i313 < _map312.size; ++_i313)
+                String _key313;
+                String _val314;
+                for (int _i315 = 0; _i315 < _map312.size; ++_i315)
                 {
-                  String _key314; // required
-                  String _val315; // required
-                  _key314 = iprot.readString();
-                  _val315 = iprot.readString();
-                  struct.properties.put(_key314, _val315);
+                  _key313 = iprot.readString();
+                  _val314 = iprot.readString();
+                  struct.properties.put(_key313, _val314);
                 }
                 iprot.readMapEnd();
               }
@@ -436,13 +429,13 @@ public class EnvironmentContext implements org.apache.thrift.TBase<EnvironmentCo
         {
           org.apache.thrift.protocol.TMap _map318 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.properties = new HashMap<String,String>(2*_map318.size);
-          for (int _i319 = 0; _i319 < _map318.size; ++_i319)
+          String _key319;
+          String _val320;
+          for (int _i321 = 0; _i321 < _map318.size; ++_i321)
           {
-            String _key320; // required
-            String _val321; // required
-            _key320 = iprot.readString();
-            _val321 = iprot.readString();
-            struct.properties.put(_key320, _val321);
+            _key319 = iprot.readString();
+            _val320 = iprot.readString();
+            struct.properties.put(_key319, _val320);
           }
         }
         struct.setPropertiesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EventRequestType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EventRequestType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EventRequestType.java
index 084c3ee..422b44f 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EventRequestType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/EventRequestType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FieldSchema.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FieldSchema.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FieldSchema.java
index a993810..358025b 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FieldSchema.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FieldSchema.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSchema._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSchema._Fields>, java.io.Serializable, Cloneable, Comparable<FieldSchema> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("FieldSchema");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -135,9 +139,9 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
     String comment)
   {
     this();
-    this.name = name;
-    this.type = type;
-    this.comment = comment;
+    this.name = org.apache.hive.common.util.HiveStringUtils.intern(name);
+    this.type = org.apache.hive.common.util.HiveStringUtils.intern(type);
+    this.comment = org.apache.hive.common.util.HiveStringUtils.intern(comment);
   }
 
   /**
@@ -145,13 +149,13 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
    */
   public FieldSchema(FieldSchema other) {
     if (other.isSetName()) {
-      this.name = other.name;
+      this.name = org.apache.hive.common.util.HiveStringUtils.intern(other.name);
     }
     if (other.isSetType()) {
-      this.type = other.type;
+      this.type = org.apache.hive.common.util.HiveStringUtils.intern(other.type);
     }
     if (other.isSetComment()) {
-      this.comment = other.comment;
+      this.comment = org.apache.hive.common.util.HiveStringUtils.intern(other.comment);
     }
   }
 
@@ -171,7 +175,7 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
   }
 
   public void setName(String name) {
-    this.name = name;
+    this.name = org.apache.hive.common.util.HiveStringUtils.intern(name);
   }
 
   public void unsetName() {
@@ -194,7 +198,7 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
   }
 
   public void setType(String type) {
-    this.type = type;
+    this.type = org.apache.hive.common.util.HiveStringUtils.intern(type);
   }
 
   public void unsetType() {
@@ -217,7 +221,7 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
   }
 
   public void setComment(String comment) {
-    this.comment = comment;
+    this.comment = org.apache.hive.common.util.HiveStringUtils.intern(comment);
   }
 
   public void unsetComment() {
@@ -341,60 +345,60 @@ public class FieldSchema implements org.apache.thrift.TBase<FieldSchema, FieldSc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_name = true && (isSetName());
-    builder.append(present_name);
+    list.add(present_name);
     if (present_name)
-      builder.append(name);
+      list.add(name);
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type);
+      list.add(type);
 
     boolean present_comment = true && (isSetComment());
-    builder.append(present_comment);
+    list.add(present_comment);
     if (present_comment)
-      builder.append(comment);
+      list.add(comment);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(FieldSchema other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    FieldSchema typedOther = (FieldSchema)other;
 
-    lastComparison = Boolean.valueOf(isSetName()).compareTo(typedOther.isSetName());
+    lastComparison = Boolean.valueOf(isSetName()).compareTo(other.isSetName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, typedOther.name);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, other.name);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetComment()).compareTo(typedOther.isSetComment());
+    lastComparison = Boolean.valueOf(isSetComment()).compareTo(other.isSetComment());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetComment()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comment, typedOther.comment);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comment, other.comment);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequest.java
index 44b83da..c19a239 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class FireEventRequest implements org.apache.thrift.TBase<FireEventRequest, FireEventRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class FireEventRequest implements org.apache.thrift.TBase<FireEventRequest, FireEventRequest._Fields>, java.io.Serializable, Cloneable, Comparable<FireEventRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("FireEventRequest");
 
   private static final org.apache.thrift.protocol.TField SUCCESSFUL_FIELD_DESC = new org.apache.thrift.protocol.TField("successful", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -125,7 +129,7 @@ public class FireEventRequest implements org.apache.thrift.TBase<FireEventReques
   // isset id assignments
   private static final int __SUCCESSFUL_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.DB_NAME,_Fields.TABLE_NAME,_Fields.PARTITION_VALS};
+  private static final _Fields optionals[] = {_Fields.DB_NAME,_Fields.TABLE_NAME,_Fields.PARTITION_VALS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -173,10 +177,7 @@ public class FireEventRequest implements org.apache.thrift.TBase<FireEventReques
       this.tableName = other.tableName;
     }
     if (other.isSetPartitionVals()) {
-      List<String> __this__partitionVals = new ArrayList<String>();
-      for (String other_element : other.partitionVals) {
-        __this__partitionVals.add(other_element);
-      }
+      List<String> __this__partitionVals = new ArrayList<String>(other.partitionVals);
       this.partitionVals = __this__partitionVals;
     }
   }
@@ -474,90 +475,90 @@ public class FireEventRequest implements org.apache.thrift.TBase<FireEventReques
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_successful = true;
-    builder.append(present_successful);
+    list.add(present_successful);
     if (present_successful)
-      builder.append(successful);
+      list.add(successful);
 
     boolean present_data = true && (isSetData());
-    builder.append(present_data);
+    list.add(present_data);
     if (present_data)
-      builder.append(data);
+      list.add(data);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_partitionVals = true && (isSetPartitionVals());
-    builder.append(present_partitionVals);
+    list.add(present_partitionVals);
     if (present_partitionVals)
-      builder.append(partitionVals);
+      list.add(partitionVals);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(FireEventRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    FireEventRequest typedOther = (FireEventRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetSuccessful()).compareTo(typedOther.isSetSuccessful());
+    lastComparison = Boolean.valueOf(isSetSuccessful()).compareTo(other.isSetSuccessful());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSuccessful()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.successful, typedOther.successful);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.successful, other.successful);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetData()).compareTo(typedOther.isSetData());
+    lastComparison = Boolean.valueOf(isSetData()).compareTo(other.isSetData());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetData()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.data, typedOther.data);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.data, other.data);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionVals()).compareTo(typedOther.isSetPartitionVals());
+    lastComparison = Boolean.valueOf(isSetPartitionVals()).compareTo(other.isSetPartitionVals());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionVals()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionVals, typedOther.partitionVals);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionVals, other.partitionVals);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -714,11 +715,11 @@ public class FireEventRequest implements org.apache.thrift.TBase<FireEventReques
               {
                 org.apache.thrift.protocol.TList _list516 = iprot.readListBegin();
                 struct.partitionVals = new ArrayList<String>(_list516.size);
-                for (int _i517 = 0; _i517 < _list516.size; ++_i517)
+                String _elem517;
+                for (int _i518 = 0; _i518 < _list516.size; ++_i518)
                 {
-                  String _elem518; // optional
-                  _elem518 = iprot.readString();
-                  struct.partitionVals.add(_elem518);
+                  _elem517 = iprot.readString();
+                  struct.partitionVals.add(_elem517);
                 }
                 iprot.readListEnd();
               }
@@ -844,11 +845,11 @@ public class FireEventRequest implements org.apache.thrift.TBase<FireEventReques
         {
           org.apache.thrift.protocol.TList _list521 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.partitionVals = new ArrayList<String>(_list521.size);
-          for (int _i522 = 0; _i522 < _list521.size; ++_i522)
+          String _elem522;
+          for (int _i523 = 0; _i523 < _list521.size; ++_i523)
           {
-            String _elem523; // optional
-            _elem523 = iprot.readString();
-            struct.partitionVals.add(_elem523);
+            _elem522 = iprot.readString();
+            struct.partitionVals.add(_elem522);
           }
         }
         struct.setPartitionValsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequestData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequestData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequestData.java
index 008682e..2830496 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequestData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventRequestData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class FireEventRequestData extends org.apache.thrift.TUnion<FireEventRequestData, FireEventRequestData._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("FireEventRequestData");
   private static final org.apache.thrift.protocol.TField INSERT_DATA_FIELD_DESC = new org.apache.thrift.protocol.TField("insertData", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -156,6 +159,7 @@ public class FireEventRequestData extends org.apache.thrift.TUnion<FireEventRequ
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -270,19 +274,19 @@ public class FireEventRequestData extends org.apache.thrift.TUnion<FireEventRequ
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventResponse.java
index 051f411..eebf057 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FireEventResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class FireEventResponse implements org.apache.thrift.TBase<FireEventResponse, FireEventResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class FireEventResponse implements org.apache.thrift.TBase<FireEventResponse, FireEventResponse._Fields>, java.io.Serializable, Cloneable, Comparable<FireEventResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("FireEventResponse");
 
 
@@ -161,18 +165,18 @@ public class FireEventResponse implements org.apache.thrift.TBase<FireEventRespo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(FireEventResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    FireEventResponse typedOther = (FireEventResponse)other;
 
     return 0;
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java
index c40e33d..0734c82 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Function implements org.apache.thrift.TBase<Function, Function._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Function implements org.apache.thrift.TBase<Function, Function._Fields>, java.io.Serializable, Cloneable, Comparable<Function> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Function");
 
   private static final org.apache.thrift.protocol.TField FUNCTION_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("functionName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -222,7 +226,7 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
       this.functionType = other.functionType;
     }
     if (other.isSetResourceUris()) {
-      List<ResourceUri> __this__resourceUris = new ArrayList<ResourceUri>();
+      List<ResourceUri> __this__resourceUris = new ArrayList<ResourceUri>(other.resourceUris.size());
       for (ResourceUri other_element : other.resourceUris) {
         __this__resourceUris.add(new ResourceUri(other_element));
       }
@@ -677,135 +681,135 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_functionName = true && (isSetFunctionName());
-    builder.append(present_functionName);
+    list.add(present_functionName);
     if (present_functionName)
-      builder.append(functionName);
+      list.add(functionName);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_className = true && (isSetClassName());
-    builder.append(present_className);
+    list.add(present_className);
     if (present_className)
-      builder.append(className);
+      list.add(className);
 
     boolean present_ownerName = true && (isSetOwnerName());
-    builder.append(present_ownerName);
+    list.add(present_ownerName);
     if (present_ownerName)
-      builder.append(ownerName);
+      list.add(ownerName);
 
     boolean present_ownerType = true && (isSetOwnerType());
-    builder.append(present_ownerType);
+    list.add(present_ownerType);
     if (present_ownerType)
-      builder.append(ownerType.getValue());
+      list.add(ownerType.getValue());
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_functionType = true && (isSetFunctionType());
-    builder.append(present_functionType);
+    list.add(present_functionType);
     if (present_functionType)
-      builder.append(functionType.getValue());
+      list.add(functionType.getValue());
 
     boolean present_resourceUris = true && (isSetResourceUris());
-    builder.append(present_resourceUris);
+    list.add(present_resourceUris);
     if (present_resourceUris)
-      builder.append(resourceUris);
+      list.add(resourceUris);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Function other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Function typedOther = (Function)other;
 
-    lastComparison = Boolean.valueOf(isSetFunctionName()).compareTo(typedOther.isSetFunctionName());
+    lastComparison = Boolean.valueOf(isSetFunctionName()).compareTo(other.isSetFunctionName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFunctionName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionName, typedOther.functionName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionName, other.functionName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetClassName()).compareTo(typedOther.isSetClassName());
+    lastComparison = Boolean.valueOf(isSetClassName()).compareTo(other.isSetClassName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetClassName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.className, typedOther.className);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.className, other.className);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(typedOther.isSetOwnerName());
+    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(other.isSetOwnerName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwnerName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, typedOther.ownerName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, other.ownerName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwnerType()).compareTo(typedOther.isSetOwnerType());
+    lastComparison = Boolean.valueOf(isSetOwnerType()).compareTo(other.isSetOwnerType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwnerType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerType, typedOther.ownerType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerType, other.ownerType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetFunctionType()).compareTo(typedOther.isSetFunctionType());
+    lastComparison = Boolean.valueOf(isSetFunctionType()).compareTo(other.isSetFunctionType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFunctionType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionType, typedOther.functionType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.functionType, other.functionType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetResourceUris()).compareTo(typedOther.isSetResourceUris());
+    lastComparison = Boolean.valueOf(isSetResourceUris()).compareTo(other.isSetResourceUris());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetResourceUris()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.resourceUris, typedOther.resourceUris);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.resourceUris, other.resourceUris);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -968,7 +972,7 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
             break;
           case 5: // OWNER_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.ownerType = PrincipalType.findByValue(iprot.readI32());
+              struct.ownerType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setOwnerTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -984,7 +988,7 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
             break;
           case 7: // FUNCTION_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.functionType = FunctionType.findByValue(iprot.readI32());
+              struct.functionType = org.apache.hadoop.hive.metastore.api.FunctionType.findByValue(iprot.readI32());
               struct.setFunctionTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -995,12 +999,12 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
               {
                 org.apache.thrift.protocol.TList _list420 = iprot.readListBegin();
                 struct.resourceUris = new ArrayList<ResourceUri>(_list420.size);
-                for (int _i421 = 0; _i421 < _list420.size; ++_i421)
+                ResourceUri _elem421;
+                for (int _i422 = 0; _i422 < _list420.size; ++_i422)
                 {
-                  ResourceUri _elem422; // optional
-                  _elem422 = new ResourceUri();
-                  _elem422.read(iprot);
-                  struct.resourceUris.add(_elem422);
+                  _elem421 = new ResourceUri();
+                  _elem421.read(iprot);
+                  struct.resourceUris.add(_elem421);
                 }
                 iprot.readListEnd();
               }
@@ -1163,7 +1167,7 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
         struct.setOwnerNameIsSet(true);
       }
       if (incoming.get(4)) {
-        struct.ownerType = PrincipalType.findByValue(iprot.readI32());
+        struct.ownerType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setOwnerTypeIsSet(true);
       }
       if (incoming.get(5)) {
@@ -1171,19 +1175,19 @@ public class Function implements org.apache.thrift.TBase<Function, Function._Fie
         struct.setCreateTimeIsSet(true);
       }
       if (incoming.get(6)) {
-        struct.functionType = FunctionType.findByValue(iprot.readI32());
+        struct.functionType = org.apache.hadoop.hive.metastore.api.FunctionType.findByValue(iprot.readI32());
         struct.setFunctionTypeIsSet(true);
       }
       if (incoming.get(7)) {
         {
           org.apache.thrift.protocol.TList _list425 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.resourceUris = new ArrayList<ResourceUri>(_list425.size);
-          for (int _i426 = 0; _i426 < _list425.size; ++_i426)
+          ResourceUri _elem426;
+          for (int _i427 = 0; _i427 < _list425.size; ++_i427)
           {
-            ResourceUri _elem427; // optional
-            _elem427 = new ResourceUri();
-            _elem427.read(iprot);
-            struct.resourceUris.add(_elem427);
+            _elem426 = new ResourceUri();
+            _elem426.read(iprot);
+            struct.resourceUris.add(_elem426);
           }
         }
         struct.setResourceUrisIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FunctionType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FunctionType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FunctionType.java
index 8f5b9b1..6958566 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FunctionType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FunctionType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java
index 9fe8d82..d04b7a6 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenTxnsInfoResponse, GetOpenTxnsInfoResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenTxnsInfoResponse, GetOpenTxnsInfoResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GetOpenTxnsInfoResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetOpenTxnsInfoResponse");
 
   private static final org.apache.thrift.protocol.TField TXN_HIGH_WATER_MARK_FIELD_DESC = new org.apache.thrift.protocol.TField("txn_high_water_mark", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -142,7 +146,7 @@ public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenT
     __isset_bitfield = other.__isset_bitfield;
     this.txn_high_water_mark = other.txn_high_water_mark;
     if (other.isSetOpen_txns()) {
-      List<TxnInfo> __this__open_txns = new ArrayList<TxnInfo>();
+      List<TxnInfo> __this__open_txns = new ArrayList<TxnInfo>(other.open_txns.size());
       for (TxnInfo other_element : other.open_txns) {
         __this__open_txns.add(new TxnInfo(other_element));
       }
@@ -305,45 +309,45 @@ public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenT
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txn_high_water_mark = true;
-    builder.append(present_txn_high_water_mark);
+    list.add(present_txn_high_water_mark);
     if (present_txn_high_water_mark)
-      builder.append(txn_high_water_mark);
+      list.add(txn_high_water_mark);
 
     boolean present_open_txns = true && (isSetOpen_txns());
-    builder.append(present_open_txns);
+    list.add(present_open_txns);
     if (present_open_txns)
-      builder.append(open_txns);
+      list.add(open_txns);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetOpenTxnsInfoResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetOpenTxnsInfoResponse typedOther = (GetOpenTxnsInfoResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetTxn_high_water_mark()).compareTo(typedOther.isSetTxn_high_water_mark());
+    lastComparison = Boolean.valueOf(isSetTxn_high_water_mark()).compareTo(other.isSetTxn_high_water_mark());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxn_high_water_mark()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_high_water_mark, typedOther.txn_high_water_mark);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_high_water_mark, other.txn_high_water_mark);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOpen_txns()).compareTo(typedOther.isSetOpen_txns());
+    lastComparison = Boolean.valueOf(isSetOpen_txns()).compareTo(other.isSetOpen_txns());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOpen_txns()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.open_txns, typedOther.open_txns);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.open_txns, other.open_txns);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -445,12 +449,12 @@ public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenT
               {
                 org.apache.thrift.protocol.TList _list428 = iprot.readListBegin();
                 struct.open_txns = new ArrayList<TxnInfo>(_list428.size);
-                for (int _i429 = 0; _i429 < _list428.size; ++_i429)
+                TxnInfo _elem429;
+                for (int _i430 = 0; _i430 < _list428.size; ++_i430)
                 {
-                  TxnInfo _elem430; // optional
-                  _elem430 = new TxnInfo();
-                  _elem430.read(iprot);
-                  struct.open_txns.add(_elem430);
+                  _elem429 = new TxnInfo();
+                  _elem429.read(iprot);
+                  struct.open_txns.add(_elem429);
                 }
                 iprot.readListEnd();
               }
@@ -522,12 +526,12 @@ public class GetOpenTxnsInfoResponse implements org.apache.thrift.TBase<GetOpenT
       {
         org.apache.thrift.protocol.TList _list433 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.open_txns = new ArrayList<TxnInfo>(_list433.size);
-        for (int _i434 = 0; _i434 < _list433.size; ++_i434)
+        TxnInfo _elem434;
+        for (int _i435 = 0; _i435 < _list433.size; ++_i435)
         {
-          TxnInfo _elem435; // optional
-          _elem435 = new TxnInfo();
-          _elem435.read(iprot);
-          struct.open_txns.add(_elem435);
+          _elem434 = new TxnInfo();
+          _elem434.read(iprot);
+          struct.open_txns.add(_elem434);
         }
       }
       struct.setOpen_txnsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java
index 917ecea..d601175 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsResponse, GetOpenTxnsResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsResponse, GetOpenTxnsResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GetOpenTxnsResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetOpenTxnsResponse");
 
   private static final org.apache.thrift.protocol.TField TXN_HIGH_WATER_MARK_FIELD_DESC = new org.apache.thrift.protocol.TField("txn_high_water_mark", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -142,10 +146,7 @@ public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsR
     __isset_bitfield = other.__isset_bitfield;
     this.txn_high_water_mark = other.txn_high_water_mark;
     if (other.isSetOpen_txns()) {
-      Set<Long> __this__open_txns = new HashSet<Long>();
-      for (Long other_element : other.open_txns) {
-        __this__open_txns.add(other_element);
-      }
+      Set<Long> __this__open_txns = new HashSet<Long>(other.open_txns);
       this.open_txns = __this__open_txns;
     }
   }
@@ -305,45 +306,45 @@ public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_txn_high_water_mark = true;
-    builder.append(present_txn_high_water_mark);
+    list.add(present_txn_high_water_mark);
     if (present_txn_high_water_mark)
-      builder.append(txn_high_water_mark);
+      list.add(txn_high_water_mark);
 
     boolean present_open_txns = true && (isSetOpen_txns());
-    builder.append(present_open_txns);
+    list.add(present_open_txns);
     if (present_open_txns)
-      builder.append(open_txns);
+      list.add(open_txns);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetOpenTxnsResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetOpenTxnsResponse typedOther = (GetOpenTxnsResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetTxn_high_water_mark()).compareTo(typedOther.isSetTxn_high_water_mark());
+    lastComparison = Boolean.valueOf(isSetTxn_high_water_mark()).compareTo(other.isSetTxn_high_water_mark());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxn_high_water_mark()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_high_water_mark, typedOther.txn_high_water_mark);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txn_high_water_mark, other.txn_high_water_mark);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOpen_txns()).compareTo(typedOther.isSetOpen_txns());
+    lastComparison = Boolean.valueOf(isSetOpen_txns()).compareTo(other.isSetOpen_txns());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOpen_txns()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.open_txns, typedOther.open_txns);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.open_txns, other.open_txns);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -445,11 +446,11 @@ public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsR
               {
                 org.apache.thrift.protocol.TSet _set436 = iprot.readSetBegin();
                 struct.open_txns = new HashSet<Long>(2*_set436.size);
-                for (int _i437 = 0; _i437 < _set436.size; ++_i437)
+                long _elem437;
+                for (int _i438 = 0; _i438 < _set436.size; ++_i438)
                 {
-                  long _elem438; // optional
-                  _elem438 = iprot.readI64();
-                  struct.open_txns.add(_elem438);
+                  _elem437 = iprot.readI64();
+                  struct.open_txns.add(_elem437);
                 }
                 iprot.readSetEnd();
               }
@@ -521,11 +522,11 @@ public class GetOpenTxnsResponse implements org.apache.thrift.TBase<GetOpenTxnsR
       {
         org.apache.thrift.protocol.TSet _set441 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, iprot.readI32());
         struct.open_txns = new HashSet<Long>(2*_set441.size);
-        for (int _i442 = 0; _i442 < _set441.size; ++_i442)
+        long _elem442;
+        for (int _i443 = 0; _i443 < _set441.size; ++_i443)
         {
-          long _elem443; // optional
-          _elem443 = iprot.readI64();
-          struct.open_txns.add(_elem443);
+          _elem442 = iprot.readI64();
+          struct.open_txns.add(_elem442);
         }
       }
       struct.setOpen_txnsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleRequest.java
index 565eba9..0df8619 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetPrincipalsInRoleRequest implements org.apache.thrift.TBase<GetPrincipalsInRoleRequest, GetPrincipalsInRoleRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetPrincipalsInRoleRequest implements org.apache.thrift.TBase<GetPrincipalsInRoleRequest, GetPrincipalsInRoleRequest._Fields>, java.io.Serializable, Cloneable, Comparable<GetPrincipalsInRoleRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetPrincipalsInRoleRequest");
 
   private static final org.apache.thrift.protocol.TField ROLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("roleName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class GetPrincipalsInRoleRequest implements org.apache.thrift.TBase<GetPr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_roleName = true && (isSetRoleName());
-    builder.append(present_roleName);
+    list.add(present_roleName);
     if (present_roleName)
-      builder.append(roleName);
+      list.add(roleName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetPrincipalsInRoleRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetPrincipalsInRoleRequest typedOther = (GetPrincipalsInRoleRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(typedOther.isSetRoleName());
+    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(other.isSetRoleName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRoleName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, typedOther.roleName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, other.roleName);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java
index 3ef6224..67684ac 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetPrincipalsInRoleResponse, GetPrincipalsInRoleResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetPrincipalsInRoleResponse, GetPrincipalsInRoleResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GetPrincipalsInRoleResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetPrincipalsInRoleResponse");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_GRANTS_FIELD_DESC = new org.apache.thrift.protocol.TField("principalGrants", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetP
    */
   public GetPrincipalsInRoleResponse(GetPrincipalsInRoleResponse other) {
     if (other.isSetPrincipalGrants()) {
-      List<RolePrincipalGrant> __this__principalGrants = new ArrayList<RolePrincipalGrant>();
+      List<RolePrincipalGrant> __this__principalGrants = new ArrayList<RolePrincipalGrant>(other.principalGrants.size());
       for (RolePrincipalGrant other_element : other.principalGrants) {
         __this__principalGrants.add(new RolePrincipalGrant(other_element));
       }
@@ -245,30 +249,30 @@ public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetP
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_principalGrants = true && (isSetPrincipalGrants());
-    builder.append(present_principalGrants);
+    list.add(present_principalGrants);
     if (present_principalGrants)
-      builder.append(principalGrants);
+      list.add(principalGrants);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetPrincipalsInRoleResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetPrincipalsInRoleResponse typedOther = (GetPrincipalsInRoleResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetPrincipalGrants()).compareTo(typedOther.isSetPrincipalGrants());
+    lastComparison = Boolean.valueOf(isSetPrincipalGrants()).compareTo(other.isSetPrincipalGrants());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalGrants()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalGrants, typedOther.principalGrants);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalGrants, other.principalGrants);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetP
               {
                 org.apache.thrift.protocol.TList _list86 = iprot.readListBegin();
                 struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list86.size);
-                for (int _i87 = 0; _i87 < _list86.size; ++_i87)
+                RolePrincipalGrant _elem87;
+                for (int _i88 = 0; _i88 < _list86.size; ++_i88)
                 {
-                  RolePrincipalGrant _elem88; // optional
-                  _elem88 = new RolePrincipalGrant();
-                  _elem88.read(iprot);
-                  struct.principalGrants.add(_elem88);
+                  _elem87 = new RolePrincipalGrant();
+                  _elem87.read(iprot);
+                  struct.principalGrants.add(_elem87);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class GetPrincipalsInRoleResponse implements org.apache.thrift.TBase<GetP
       {
         org.apache.thrift.protocol.TList _list91 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list91.size);
-        for (int _i92 = 0; _i92 < _list91.size; ++_i92)
+        RolePrincipalGrant _elem92;
+        for (int _i93 = 0; _i93 < _list91.size; ++_i93)
         {
-          RolePrincipalGrant _elem93; // optional
-          _elem93 = new RolePrincipalGrant();
-          _elem93.read(iprot);
-          struct.principalGrants.add(_elem93);
+          _elem92 = new RolePrincipalGrant();
+          _elem92.read(iprot);
+          struct.principalGrants.add(_elem92);
         }
       }
       struct.setPrincipalGrantsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalRequest.java
index 84b73c3..3ab34ee 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetRoleGrantsForPrincipalRequest implements org.apache.thrift.TBase<GetRoleGrantsForPrincipalRequest, GetRoleGrantsForPrincipalRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetRoleGrantsForPrincipalRequest implements org.apache.thrift.TBase<GetRoleGrantsForPrincipalRequest, GetRoleGrantsForPrincipalRequest._Fields>, java.io.Serializable, Cloneable, Comparable<GetRoleGrantsForPrincipalRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetRoleGrantsForPrincipalRequest");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("principal_name", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -295,45 +299,45 @@ public class GetRoleGrantsForPrincipalRequest implements org.apache.thrift.TBase
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_principal_name = true && (isSetPrincipal_name());
-    builder.append(present_principal_name);
+    list.add(present_principal_name);
     if (present_principal_name)
-      builder.append(principal_name);
+      list.add(principal_name);
 
     boolean present_principal_type = true && (isSetPrincipal_type());
-    builder.append(present_principal_type);
+    list.add(present_principal_type);
     if (present_principal_type)
-      builder.append(principal_type.getValue());
+      list.add(principal_type.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetRoleGrantsForPrincipalRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetRoleGrantsForPrincipalRequest typedOther = (GetRoleGrantsForPrincipalRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetPrincipal_name()).compareTo(typedOther.isSetPrincipal_name());
+    lastComparison = Boolean.valueOf(isSetPrincipal_name()).compareTo(other.isSetPrincipal_name());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipal_name()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principal_name, typedOther.principal_name);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principal_name, other.principal_name);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipal_type()).compareTo(typedOther.isSetPrincipal_type());
+    lastComparison = Boolean.valueOf(isSetPrincipal_type()).compareTo(other.isSetPrincipal_type());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipal_type()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principal_type, typedOther.principal_type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principal_type, other.principal_type);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -434,7 +438,7 @@ public class GetRoleGrantsForPrincipalRequest implements org.apache.thrift.TBase
             break;
           case 2: // PRINCIPAL_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.principal_type = PrincipalType.findByValue(iprot.readI32());
+              struct.principal_type = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setPrincipal_typeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -489,7 +493,7 @@ public class GetRoleGrantsForPrincipalRequest implements org.apache.thrift.TBase
       TTupleProtocol iprot = (TTupleProtocol) prot;
       struct.principal_name = iprot.readString();
       struct.setPrincipal_nameIsSet(true);
-      struct.principal_type = PrincipalType.findByValue(iprot.readI32());
+      struct.principal_type = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
       struct.setPrincipal_typeIsSet(true);
     }
   }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java
index 3ddc1ac..f1c6c02 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBase<GetRoleGrantsForPrincipalResponse, GetRoleGrantsForPrincipalResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBase<GetRoleGrantsForPrincipalResponse, GetRoleGrantsForPrincipalResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GetRoleGrantsForPrincipalResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GetRoleGrantsForPrincipalResponse");
 
   private static final org.apache.thrift.protocol.TField PRINCIPAL_GRANTS_FIELD_DESC = new org.apache.thrift.protocol.TField("principalGrants", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBas
    */
   public GetRoleGrantsForPrincipalResponse(GetRoleGrantsForPrincipalResponse other) {
     if (other.isSetPrincipalGrants()) {
-      List<RolePrincipalGrant> __this__principalGrants = new ArrayList<RolePrincipalGrant>();
+      List<RolePrincipalGrant> __this__principalGrants = new ArrayList<RolePrincipalGrant>(other.principalGrants.size());
       for (RolePrincipalGrant other_element : other.principalGrants) {
         __this__principalGrants.add(new RolePrincipalGrant(other_element));
       }
@@ -245,30 +249,30 @@ public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBas
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_principalGrants = true && (isSetPrincipalGrants());
-    builder.append(present_principalGrants);
+    list.add(present_principalGrants);
     if (present_principalGrants)
-      builder.append(principalGrants);
+      list.add(principalGrants);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GetRoleGrantsForPrincipalResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GetRoleGrantsForPrincipalResponse typedOther = (GetRoleGrantsForPrincipalResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetPrincipalGrants()).compareTo(typedOther.isSetPrincipalGrants());
+    lastComparison = Boolean.valueOf(isSetPrincipalGrants()).compareTo(other.isSetPrincipalGrants());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalGrants()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalGrants, typedOther.principalGrants);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalGrants, other.principalGrants);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBas
               {
                 org.apache.thrift.protocol.TList _list78 = iprot.readListBegin();
                 struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list78.size);
-                for (int _i79 = 0; _i79 < _list78.size; ++_i79)
+                RolePrincipalGrant _elem79;
+                for (int _i80 = 0; _i80 < _list78.size; ++_i80)
                 {
-                  RolePrincipalGrant _elem80; // optional
-                  _elem80 = new RolePrincipalGrant();
-                  _elem80.read(iprot);
-                  struct.principalGrants.add(_elem80);
+                  _elem79 = new RolePrincipalGrant();
+                  _elem79.read(iprot);
+                  struct.principalGrants.add(_elem79);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class GetRoleGrantsForPrincipalResponse implements org.apache.thrift.TBas
       {
         org.apache.thrift.protocol.TList _list83 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list83.size);
-        for (int _i84 = 0; _i84 < _list83.size; ++_i84)
+        RolePrincipalGrant _elem84;
+        for (int _i85 = 0; _i85 < _list83.size; ++_i85)
         {
-          RolePrincipalGrant _elem85; // optional
-          _elem85 = new RolePrincipalGrant();
-          _elem85.read(iprot);
-          struct.principalGrants.add(_elem85);
+          _elem84 = new RolePrincipalGrant();
+          _elem84.read(iprot);
+          struct.principalGrants.add(_elem84);
         }
       }
       struct.setPrincipalGrantsIsSet(true);


[25/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Operator.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Operator.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Operator.java
index f1c9e2d..52cccad 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Operator.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Operator.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fields>, java.io.Serializable, Cloneable, Comparable<Operator> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Operator");
 
   private static final org.apache.thrift.protocol.TField OPERATOR_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("operatorId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -192,33 +196,11 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
       this.operatorType = other.operatorType;
     }
     if (other.isSetOperatorAttributes()) {
-      Map<String,String> __this__operatorAttributes = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.operatorAttributes.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__operatorAttributes_copy_key = other_element_key;
-
-        String __this__operatorAttributes_copy_value = other_element_value;
-
-        __this__operatorAttributes.put(__this__operatorAttributes_copy_key, __this__operatorAttributes_copy_value);
-      }
+      Map<String,String> __this__operatorAttributes = new HashMap<String,String>(other.operatorAttributes);
       this.operatorAttributes = __this__operatorAttributes;
     }
     if (other.isSetOperatorCounters()) {
-      Map<String,Long> __this__operatorCounters = new HashMap<String,Long>();
-      for (Map.Entry<String, Long> other_element : other.operatorCounters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        Long other_element_value = other_element.getValue();
-
-        String __this__operatorCounters_copy_key = other_element_key;
-
-        Long __this__operatorCounters_copy_value = other_element_value;
-
-        __this__operatorCounters.put(__this__operatorCounters_copy_key, __this__operatorCounters_copy_value);
-      }
+      Map<String,Long> __this__operatorCounters = new HashMap<String,Long>(other.operatorCounters);
       this.operatorCounters = __this__operatorCounters;
     }
     this.done = other.done;
@@ -579,105 +561,105 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operatorId = true && (isSetOperatorId());
-    builder.append(present_operatorId);
+    list.add(present_operatorId);
     if (present_operatorId)
-      builder.append(operatorId);
+      list.add(operatorId);
 
     boolean present_operatorType = true && (isSetOperatorType());
-    builder.append(present_operatorType);
+    list.add(present_operatorType);
     if (present_operatorType)
-      builder.append(operatorType.getValue());
+      list.add(operatorType.getValue());
 
     boolean present_operatorAttributes = true && (isSetOperatorAttributes());
-    builder.append(present_operatorAttributes);
+    list.add(present_operatorAttributes);
     if (present_operatorAttributes)
-      builder.append(operatorAttributes);
+      list.add(operatorAttributes);
 
     boolean present_operatorCounters = true && (isSetOperatorCounters());
-    builder.append(present_operatorCounters);
+    list.add(present_operatorCounters);
     if (present_operatorCounters)
-      builder.append(operatorCounters);
+      list.add(operatorCounters);
 
     boolean present_done = true;
-    builder.append(present_done);
+    list.add(present_done);
     if (present_done)
-      builder.append(done);
+      list.add(done);
 
     boolean present_started = true;
-    builder.append(present_started);
+    list.add(present_started);
     if (present_started)
-      builder.append(started);
+      list.add(started);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Operator other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Operator typedOther = (Operator)other;
 
-    lastComparison = Boolean.valueOf(isSetOperatorId()).compareTo(typedOther.isSetOperatorId());
+    lastComparison = Boolean.valueOf(isSetOperatorId()).compareTo(other.isSetOperatorId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorId, typedOther.operatorId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorId, other.operatorId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperatorType()).compareTo(typedOther.isSetOperatorType());
+    lastComparison = Boolean.valueOf(isSetOperatorType()).compareTo(other.isSetOperatorType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorType, typedOther.operatorType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorType, other.operatorType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperatorAttributes()).compareTo(typedOther.isSetOperatorAttributes());
+    lastComparison = Boolean.valueOf(isSetOperatorAttributes()).compareTo(other.isSetOperatorAttributes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorAttributes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorAttributes, typedOther.operatorAttributes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorAttributes, other.operatorAttributes);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperatorCounters()).compareTo(typedOther.isSetOperatorCounters());
+    lastComparison = Boolean.valueOf(isSetOperatorCounters()).compareTo(other.isSetOperatorCounters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorCounters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorCounters, typedOther.operatorCounters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorCounters, other.operatorCounters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDone()).compareTo(typedOther.isSetDone());
+    lastComparison = Boolean.valueOf(isSetDone()).compareTo(other.isSetDone());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDone()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, typedOther.done);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, other.done);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(typedOther.isSetStarted());
+    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(other.isSetStarted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStarted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, typedOther.started);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, other.started);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -796,7 +778,7 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
             break;
           case 2: // OPERATOR_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.operatorType = OperatorType.findByValue(iprot.readI32());
+              struct.operatorType = org.apache.hadoop.hive.ql.plan.api.OperatorType.findByValue(iprot.readI32());
               struct.setOperatorTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -807,13 +789,13 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
               {
                 org.apache.thrift.protocol.TMap _map24 = iprot.readMapBegin();
                 struct.operatorAttributes = new HashMap<String,String>(2*_map24.size);
-                for (int _i25 = 0; _i25 < _map24.size; ++_i25)
+                String _key25;
+                String _val26;
+                for (int _i27 = 0; _i27 < _map24.size; ++_i27)
                 {
-                  String _key26; // required
-                  String _val27; // required
-                  _key26 = iprot.readString();
-                  _val27 = iprot.readString();
-                  struct.operatorAttributes.put(_key26, _val27);
+                  _key25 = iprot.readString();
+                  _val26 = iprot.readString();
+                  struct.operatorAttributes.put(_key25, _val26);
                 }
                 iprot.readMapEnd();
               }
@@ -827,13 +809,13 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
               {
                 org.apache.thrift.protocol.TMap _map28 = iprot.readMapBegin();
                 struct.operatorCounters = new HashMap<String,Long>(2*_map28.size);
-                for (int _i29 = 0; _i29 < _map28.size; ++_i29)
+                String _key29;
+                long _val30;
+                for (int _i31 = 0; _i31 < _map28.size; ++_i31)
                 {
-                  String _key30; // required
-                  long _val31; // required
-                  _key30 = iprot.readString();
-                  _val31 = iprot.readI64();
-                  struct.operatorCounters.put(_key30, _val31);
+                  _key29 = iprot.readString();
+                  _val30 = iprot.readI64();
+                  struct.operatorCounters.put(_key29, _val30);
                 }
                 iprot.readMapEnd();
               }
@@ -993,20 +975,20 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
         struct.setOperatorIdIsSet(true);
       }
       if (incoming.get(1)) {
-        struct.operatorType = OperatorType.findByValue(iprot.readI32());
+        struct.operatorType = org.apache.hadoop.hive.ql.plan.api.OperatorType.findByValue(iprot.readI32());
         struct.setOperatorTypeIsSet(true);
       }
       if (incoming.get(2)) {
         {
           org.apache.thrift.protocol.TMap _map36 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.operatorAttributes = new HashMap<String,String>(2*_map36.size);
-          for (int _i37 = 0; _i37 < _map36.size; ++_i37)
+          String _key37;
+          String _val38;
+          for (int _i39 = 0; _i39 < _map36.size; ++_i39)
           {
-            String _key38; // required
-            String _val39; // required
-            _key38 = iprot.readString();
-            _val39 = iprot.readString();
-            struct.operatorAttributes.put(_key38, _val39);
+            _key37 = iprot.readString();
+            _val38 = iprot.readString();
+            struct.operatorAttributes.put(_key37, _val38);
           }
         }
         struct.setOperatorAttributesIsSet(true);
@@ -1015,13 +997,13 @@ public class Operator implements org.apache.thrift.TBase<Operator, Operator._Fie
         {
           org.apache.thrift.protocol.TMap _map40 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I64, iprot.readI32());
           struct.operatorCounters = new HashMap<String,Long>(2*_map40.size);
-          for (int _i41 = 0; _i41 < _map40.size; ++_i41)
+          String _key41;
+          long _val42;
+          for (int _i43 = 0; _i43 < _map40.size; ++_i43)
           {
-            String _key42; // required
-            long _val43; // required
-            _key42 = iprot.readString();
-            _val43 = iprot.readI64();
-            struct.operatorCounters.put(_key42, _val43);
+            _key41 = iprot.readString();
+            _val42 = iprot.readI64();
+            struct.operatorCounters.put(_key41, _val42);
           }
         }
         struct.setOperatorCountersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/OperatorType.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/OperatorType.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/OperatorType.java
index e18f935..1d17dcb 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/OperatorType.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/OperatorType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -36,7 +36,8 @@ public enum OperatorType implements org.apache.thrift.TEnum {
   EVENT(21),
   ORCFILEMERGE(22),
   RCFILEMERGE(23),
-  MERGEJOIN(24);
+  MERGEJOIN(24),
+  SPARKPRUNINGSINK(25);
 
   private final int value;
 
@@ -107,6 +108,8 @@ public enum OperatorType implements org.apache.thrift.TEnum {
         return RCFILEMERGE;
       case 24:
         return MERGEJOIN;
+      case 25:
+        return SPARKPRUNINGSINK;
       default:
         return null;
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Query.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Query.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Query.java
index e0d77e8..bd6c7ca 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Query.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Query.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, java.io.Serializable, Cloneable, Comparable<Query> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Query");
 
   private static final org.apache.thrift.protocol.TField QUERY_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("queryId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -207,40 +211,18 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
       this.queryType = other.queryType;
     }
     if (other.isSetQueryAttributes()) {
-      Map<String,String> __this__queryAttributes = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.queryAttributes.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__queryAttributes_copy_key = other_element_key;
-
-        String __this__queryAttributes_copy_value = other_element_value;
-
-        __this__queryAttributes.put(__this__queryAttributes_copy_key, __this__queryAttributes_copy_value);
-      }
+      Map<String,String> __this__queryAttributes = new HashMap<String,String>(other.queryAttributes);
       this.queryAttributes = __this__queryAttributes;
     }
     if (other.isSetQueryCounters()) {
-      Map<String,Long> __this__queryCounters = new HashMap<String,Long>();
-      for (Map.Entry<String, Long> other_element : other.queryCounters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        Long other_element_value = other_element.getValue();
-
-        String __this__queryCounters_copy_key = other_element_key;
-
-        Long __this__queryCounters_copy_value = other_element_value;
-
-        __this__queryCounters.put(__this__queryCounters_copy_key, __this__queryCounters_copy_value);
-      }
+      Map<String,Long> __this__queryCounters = new HashMap<String,Long>(other.queryCounters);
       this.queryCounters = __this__queryCounters;
     }
     if (other.isSetStageGraph()) {
       this.stageGraph = new Graph(other.stageGraph);
     }
     if (other.isSetStageList()) {
-      List<Stage> __this__stageList = new ArrayList<Stage>();
+      List<Stage> __this__stageList = new ArrayList<Stage>(other.stageList.size());
       for (Stage other_element : other.stageList) {
         __this__stageList.add(new Stage(other_element));
       }
@@ -703,135 +685,135 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_queryId = true && (isSetQueryId());
-    builder.append(present_queryId);
+    list.add(present_queryId);
     if (present_queryId)
-      builder.append(queryId);
+      list.add(queryId);
 
     boolean present_queryType = true && (isSetQueryType());
-    builder.append(present_queryType);
+    list.add(present_queryType);
     if (present_queryType)
-      builder.append(queryType);
+      list.add(queryType);
 
     boolean present_queryAttributes = true && (isSetQueryAttributes());
-    builder.append(present_queryAttributes);
+    list.add(present_queryAttributes);
     if (present_queryAttributes)
-      builder.append(queryAttributes);
+      list.add(queryAttributes);
 
     boolean present_queryCounters = true && (isSetQueryCounters());
-    builder.append(present_queryCounters);
+    list.add(present_queryCounters);
     if (present_queryCounters)
-      builder.append(queryCounters);
+      list.add(queryCounters);
 
     boolean present_stageGraph = true && (isSetStageGraph());
-    builder.append(present_stageGraph);
+    list.add(present_stageGraph);
     if (present_stageGraph)
-      builder.append(stageGraph);
+      list.add(stageGraph);
 
     boolean present_stageList = true && (isSetStageList());
-    builder.append(present_stageList);
+    list.add(present_stageList);
     if (present_stageList)
-      builder.append(stageList);
+      list.add(stageList);
 
     boolean present_done = true;
-    builder.append(present_done);
+    list.add(present_done);
     if (present_done)
-      builder.append(done);
+      list.add(done);
 
     boolean present_started = true;
-    builder.append(present_started);
+    list.add(present_started);
     if (present_started)
-      builder.append(started);
+      list.add(started);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Query other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Query typedOther = (Query)other;
 
-    lastComparison = Boolean.valueOf(isSetQueryId()).compareTo(typedOther.isSetQueryId());
+    lastComparison = Boolean.valueOf(isSetQueryId()).compareTo(other.isSetQueryId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQueryId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryId, typedOther.queryId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryId, other.queryId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetQueryType()).compareTo(typedOther.isSetQueryType());
+    lastComparison = Boolean.valueOf(isSetQueryType()).compareTo(other.isSetQueryType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQueryType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryType, typedOther.queryType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryType, other.queryType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetQueryAttributes()).compareTo(typedOther.isSetQueryAttributes());
+    lastComparison = Boolean.valueOf(isSetQueryAttributes()).compareTo(other.isSetQueryAttributes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQueryAttributes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryAttributes, typedOther.queryAttributes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryAttributes, other.queryAttributes);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetQueryCounters()).compareTo(typedOther.isSetQueryCounters());
+    lastComparison = Boolean.valueOf(isSetQueryCounters()).compareTo(other.isSetQueryCounters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQueryCounters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryCounters, typedOther.queryCounters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queryCounters, other.queryCounters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStageGraph()).compareTo(typedOther.isSetStageGraph());
+    lastComparison = Boolean.valueOf(isSetStageGraph()).compareTo(other.isSetStageGraph());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageGraph()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageGraph, typedOther.stageGraph);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageGraph, other.stageGraph);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStageList()).compareTo(typedOther.isSetStageList());
+    lastComparison = Boolean.valueOf(isSetStageList()).compareTo(other.isSetStageList());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageList()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageList, typedOther.stageList);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageList, other.stageList);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDone()).compareTo(typedOther.isSetDone());
+    lastComparison = Boolean.valueOf(isSetDone()).compareTo(other.isSetDone());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDone()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, typedOther.done);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, other.done);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(typedOther.isSetStarted());
+    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(other.isSetStarted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStarted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, typedOther.started);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, other.started);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -980,13 +962,13 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map100 = iprot.readMapBegin();
                 struct.queryAttributes = new HashMap<String,String>(2*_map100.size);
-                for (int _i101 = 0; _i101 < _map100.size; ++_i101)
+                String _key101;
+                String _val102;
+                for (int _i103 = 0; _i103 < _map100.size; ++_i103)
                 {
-                  String _key102; // required
-                  String _val103; // required
-                  _key102 = iprot.readString();
-                  _val103 = iprot.readString();
-                  struct.queryAttributes.put(_key102, _val103);
+                  _key101 = iprot.readString();
+                  _val102 = iprot.readString();
+                  struct.queryAttributes.put(_key101, _val102);
                 }
                 iprot.readMapEnd();
               }
@@ -1000,13 +982,13 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map104 = iprot.readMapBegin();
                 struct.queryCounters = new HashMap<String,Long>(2*_map104.size);
-                for (int _i105 = 0; _i105 < _map104.size; ++_i105)
+                String _key105;
+                long _val106;
+                for (int _i107 = 0; _i107 < _map104.size; ++_i107)
                 {
-                  String _key106; // required
-                  long _val107; // required
-                  _key106 = iprot.readString();
-                  _val107 = iprot.readI64();
-                  struct.queryCounters.put(_key106, _val107);
+                  _key105 = iprot.readString();
+                  _val106 = iprot.readI64();
+                  struct.queryCounters.put(_key105, _val106);
                 }
                 iprot.readMapEnd();
               }
@@ -1029,12 +1011,12 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
               {
                 org.apache.thrift.protocol.TList _list108 = iprot.readListBegin();
                 struct.stageList = new ArrayList<Stage>(_list108.size);
-                for (int _i109 = 0; _i109 < _list108.size; ++_i109)
+                Stage _elem109;
+                for (int _i110 = 0; _i110 < _list108.size; ++_i110)
                 {
-                  Stage _elem110; // required
-                  _elem110 = new Stage();
-                  _elem110.read(iprot);
-                  struct.stageList.add(_elem110);
+                  _elem109 = new Stage();
+                  _elem109.read(iprot);
+                  struct.stageList.add(_elem109);
                 }
                 iprot.readListEnd();
               }
@@ -1236,13 +1218,13 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
         {
           org.apache.thrift.protocol.TMap _map117 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.queryAttributes = new HashMap<String,String>(2*_map117.size);
-          for (int _i118 = 0; _i118 < _map117.size; ++_i118)
+          String _key118;
+          String _val119;
+          for (int _i120 = 0; _i120 < _map117.size; ++_i120)
           {
-            String _key119; // required
-            String _val120; // required
-            _key119 = iprot.readString();
-            _val120 = iprot.readString();
-            struct.queryAttributes.put(_key119, _val120);
+            _key118 = iprot.readString();
+            _val119 = iprot.readString();
+            struct.queryAttributes.put(_key118, _val119);
           }
         }
         struct.setQueryAttributesIsSet(true);
@@ -1251,13 +1233,13 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
         {
           org.apache.thrift.protocol.TMap _map121 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I64, iprot.readI32());
           struct.queryCounters = new HashMap<String,Long>(2*_map121.size);
-          for (int _i122 = 0; _i122 < _map121.size; ++_i122)
+          String _key122;
+          long _val123;
+          for (int _i124 = 0; _i124 < _map121.size; ++_i124)
           {
-            String _key123; // required
-            long _val124; // required
-            _key123 = iprot.readString();
-            _val124 = iprot.readI64();
-            struct.queryCounters.put(_key123, _val124);
+            _key122 = iprot.readString();
+            _val123 = iprot.readI64();
+            struct.queryCounters.put(_key122, _val123);
           }
         }
         struct.setQueryCountersIsSet(true);
@@ -1271,12 +1253,12 @@ public class Query implements org.apache.thrift.TBase<Query, Query._Fields>, jav
         {
           org.apache.thrift.protocol.TList _list125 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.stageList = new ArrayList<Stage>(_list125.size);
-          for (int _i126 = 0; _i126 < _list125.size; ++_i126)
+          Stage _elem126;
+          for (int _i127 = 0; _i127 < _list125.size; ++_i127)
           {
-            Stage _elem127; // required
-            _elem127 = new Stage();
-            _elem127.read(iprot);
-            struct.stageList.add(_elem127);
+            _elem126 = new Stage();
+            _elem126.read(iprot);
+            struct.stageList.add(_elem126);
           }
         }
         struct.setStageListIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/QueryPlan.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/QueryPlan.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/QueryPlan.java
index e8566a5..8bae7ad 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/QueryPlan.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/QueryPlan.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._Fields>, java.io.Serializable, Cloneable, Comparable<QueryPlan> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("QueryPlan");
 
   private static final org.apache.thrift.protocol.TField QUERIES_FIELD_DESC = new org.apache.thrift.protocol.TField("queries", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -152,7 +156,7 @@ public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._
   public QueryPlan(QueryPlan other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetQueries()) {
-      List<Query> __this__queries = new ArrayList<Query>();
+      List<Query> __this__queries = new ArrayList<Query>(other.queries.size());
       for (Query other_element : other.queries) {
         __this__queries.add(new Query(other_element));
       }
@@ -363,60 +367,60 @@ public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_queries = true && (isSetQueries());
-    builder.append(present_queries);
+    list.add(present_queries);
     if (present_queries)
-      builder.append(queries);
+      list.add(queries);
 
     boolean present_done = true;
-    builder.append(present_done);
+    list.add(present_done);
     if (present_done)
-      builder.append(done);
+      list.add(done);
 
     boolean present_started = true;
-    builder.append(present_started);
+    list.add(present_started);
     if (present_started)
-      builder.append(started);
+      list.add(started);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(QueryPlan other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    QueryPlan typedOther = (QueryPlan)other;
 
-    lastComparison = Boolean.valueOf(isSetQueries()).compareTo(typedOther.isSetQueries());
+    lastComparison = Boolean.valueOf(isSetQueries()).compareTo(other.isSetQueries());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetQueries()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queries, typedOther.queries);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.queries, other.queries);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDone()).compareTo(typedOther.isSetDone());
+    lastComparison = Boolean.valueOf(isSetDone()).compareTo(other.isSetDone());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDone()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, typedOther.done);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, other.done);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(typedOther.isSetStarted());
+    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(other.isSetStarted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStarted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, typedOther.started);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, other.started);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -506,12 +510,12 @@ public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._
               {
                 org.apache.thrift.protocol.TList _list128 = iprot.readListBegin();
                 struct.queries = new ArrayList<Query>(_list128.size);
-                for (int _i129 = 0; _i129 < _list128.size; ++_i129)
+                Query _elem129;
+                for (int _i130 = 0; _i130 < _list128.size; ++_i130)
                 {
-                  Query _elem130; // required
-                  _elem130 = new Query();
-                  _elem130.read(iprot);
-                  struct.queries.add(_elem130);
+                  _elem129 = new Query();
+                  _elem129.read(iprot);
+                  struct.queries.add(_elem129);
                 }
                 iprot.readListEnd();
               }
@@ -620,12 +624,12 @@ public class QueryPlan implements org.apache.thrift.TBase<QueryPlan, QueryPlan._
         {
           org.apache.thrift.protocol.TList _list133 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.queries = new ArrayList<Query>(_list133.size);
-          for (int _i134 = 0; _i134 < _list133.size; ++_i134)
+          Query _elem134;
+          for (int _i135 = 0; _i135 < _list133.size; ++_i135)
           {
-            Query _elem135; // required
-            _elem135 = new Query();
-            _elem135.read(iprot);
-            struct.queries.add(_elem135);
+            _elem134 = new Query();
+            _elem134.read(iprot);
+            struct.queries.add(_elem134);
           }
         }
         struct.setQueriesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Stage.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Stage.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Stage.java
index c341db2..82a2b92 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Stage.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Stage.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, java.io.Serializable, Cloneable, Comparable<Stage> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Stage");
 
   private static final org.apache.thrift.protocol.TField STAGE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("stageId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -202,37 +206,15 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
       this.stageType = other.stageType;
     }
     if (other.isSetStageAttributes()) {
-      Map<String,String> __this__stageAttributes = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.stageAttributes.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__stageAttributes_copy_key = other_element_key;
-
-        String __this__stageAttributes_copy_value = other_element_value;
-
-        __this__stageAttributes.put(__this__stageAttributes_copy_key, __this__stageAttributes_copy_value);
-      }
+      Map<String,String> __this__stageAttributes = new HashMap<String,String>(other.stageAttributes);
       this.stageAttributes = __this__stageAttributes;
     }
     if (other.isSetStageCounters()) {
-      Map<String,Long> __this__stageCounters = new HashMap<String,Long>();
-      for (Map.Entry<String, Long> other_element : other.stageCounters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        Long other_element_value = other_element.getValue();
-
-        String __this__stageCounters_copy_key = other_element_key;
-
-        Long __this__stageCounters_copy_value = other_element_value;
-
-        __this__stageCounters.put(__this__stageCounters_copy_key, __this__stageCounters_copy_value);
-      }
+      Map<String,Long> __this__stageCounters = new HashMap<String,Long>(other.stageCounters);
       this.stageCounters = __this__stageCounters;
     }
     if (other.isSetTaskList()) {
-      List<Task> __this__taskList = new ArrayList<Task>();
+      List<Task> __this__taskList = new ArrayList<Task>(other.taskList.size());
       for (Task other_element : other.taskList) {
         __this__taskList.add(new Task(other_element));
       }
@@ -657,120 +639,120 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_stageId = true && (isSetStageId());
-    builder.append(present_stageId);
+    list.add(present_stageId);
     if (present_stageId)
-      builder.append(stageId);
+      list.add(stageId);
 
     boolean present_stageType = true && (isSetStageType());
-    builder.append(present_stageType);
+    list.add(present_stageType);
     if (present_stageType)
-      builder.append(stageType.getValue());
+      list.add(stageType.getValue());
 
     boolean present_stageAttributes = true && (isSetStageAttributes());
-    builder.append(present_stageAttributes);
+    list.add(present_stageAttributes);
     if (present_stageAttributes)
-      builder.append(stageAttributes);
+      list.add(stageAttributes);
 
     boolean present_stageCounters = true && (isSetStageCounters());
-    builder.append(present_stageCounters);
+    list.add(present_stageCounters);
     if (present_stageCounters)
-      builder.append(stageCounters);
+      list.add(stageCounters);
 
     boolean present_taskList = true && (isSetTaskList());
-    builder.append(present_taskList);
+    list.add(present_taskList);
     if (present_taskList)
-      builder.append(taskList);
+      list.add(taskList);
 
     boolean present_done = true;
-    builder.append(present_done);
+    list.add(present_done);
     if (present_done)
-      builder.append(done);
+      list.add(done);
 
     boolean present_started = true;
-    builder.append(present_started);
+    list.add(present_started);
     if (present_started)
-      builder.append(started);
+      list.add(started);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Stage other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Stage typedOther = (Stage)other;
 
-    lastComparison = Boolean.valueOf(isSetStageId()).compareTo(typedOther.isSetStageId());
+    lastComparison = Boolean.valueOf(isSetStageId()).compareTo(other.isSetStageId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageId, typedOther.stageId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageId, other.stageId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStageType()).compareTo(typedOther.isSetStageType());
+    lastComparison = Boolean.valueOf(isSetStageType()).compareTo(other.isSetStageType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageType, typedOther.stageType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageType, other.stageType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStageAttributes()).compareTo(typedOther.isSetStageAttributes());
+    lastComparison = Boolean.valueOf(isSetStageAttributes()).compareTo(other.isSetStageAttributes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageAttributes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageAttributes, typedOther.stageAttributes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageAttributes, other.stageAttributes);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStageCounters()).compareTo(typedOther.isSetStageCounters());
+    lastComparison = Boolean.valueOf(isSetStageCounters()).compareTo(other.isSetStageCounters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStageCounters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageCounters, typedOther.stageCounters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.stageCounters, other.stageCounters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTaskList()).compareTo(typedOther.isSetTaskList());
+    lastComparison = Boolean.valueOf(isSetTaskList()).compareTo(other.isSetTaskList());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskList()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskList, typedOther.taskList);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskList, other.taskList);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDone()).compareTo(typedOther.isSetDone());
+    lastComparison = Boolean.valueOf(isSetDone()).compareTo(other.isSetDone());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDone()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, typedOther.done);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, other.done);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(typedOther.isSetStarted());
+    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(other.isSetStarted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStarted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, typedOther.started);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, other.started);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -897,7 +879,7 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
             break;
           case 2: // STAGE_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.stageType = StageType.findByValue(iprot.readI32());
+              struct.stageType = org.apache.hadoop.hive.ql.plan.api.StageType.findByValue(iprot.readI32());
               struct.setStageTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -908,13 +890,13 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map72 = iprot.readMapBegin();
                 struct.stageAttributes = new HashMap<String,String>(2*_map72.size);
-                for (int _i73 = 0; _i73 < _map72.size; ++_i73)
+                String _key73;
+                String _val74;
+                for (int _i75 = 0; _i75 < _map72.size; ++_i75)
                 {
-                  String _key74; // required
-                  String _val75; // required
-                  _key74 = iprot.readString();
-                  _val75 = iprot.readString();
-                  struct.stageAttributes.put(_key74, _val75);
+                  _key73 = iprot.readString();
+                  _val74 = iprot.readString();
+                  struct.stageAttributes.put(_key73, _val74);
                 }
                 iprot.readMapEnd();
               }
@@ -928,13 +910,13 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map76 = iprot.readMapBegin();
                 struct.stageCounters = new HashMap<String,Long>(2*_map76.size);
-                for (int _i77 = 0; _i77 < _map76.size; ++_i77)
+                String _key77;
+                long _val78;
+                for (int _i79 = 0; _i79 < _map76.size; ++_i79)
                 {
-                  String _key78; // required
-                  long _val79; // required
-                  _key78 = iprot.readString();
-                  _val79 = iprot.readI64();
-                  struct.stageCounters.put(_key78, _val79);
+                  _key77 = iprot.readString();
+                  _val78 = iprot.readI64();
+                  struct.stageCounters.put(_key77, _val78);
                 }
                 iprot.readMapEnd();
               }
@@ -948,12 +930,12 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
               {
                 org.apache.thrift.protocol.TList _list80 = iprot.readListBegin();
                 struct.taskList = new ArrayList<Task>(_list80.size);
-                for (int _i81 = 0; _i81 < _list80.size; ++_i81)
+                Task _elem81;
+                for (int _i82 = 0; _i82 < _list80.size; ++_i82)
                 {
-                  Task _elem82; // required
-                  _elem82 = new Task();
-                  _elem82.read(iprot);
-                  struct.taskList.add(_elem82);
+                  _elem81 = new Task();
+                  _elem81.read(iprot);
+                  struct.taskList.add(_elem81);
                 }
                 iprot.readListEnd();
               }
@@ -1137,20 +1119,20 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
         struct.setStageIdIsSet(true);
       }
       if (incoming.get(1)) {
-        struct.stageType = StageType.findByValue(iprot.readI32());
+        struct.stageType = org.apache.hadoop.hive.ql.plan.api.StageType.findByValue(iprot.readI32());
         struct.setStageTypeIsSet(true);
       }
       if (incoming.get(2)) {
         {
           org.apache.thrift.protocol.TMap _map89 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.stageAttributes = new HashMap<String,String>(2*_map89.size);
-          for (int _i90 = 0; _i90 < _map89.size; ++_i90)
+          String _key90;
+          String _val91;
+          for (int _i92 = 0; _i92 < _map89.size; ++_i92)
           {
-            String _key91; // required
-            String _val92; // required
-            _key91 = iprot.readString();
-            _val92 = iprot.readString();
-            struct.stageAttributes.put(_key91, _val92);
+            _key90 = iprot.readString();
+            _val91 = iprot.readString();
+            struct.stageAttributes.put(_key90, _val91);
           }
         }
         struct.setStageAttributesIsSet(true);
@@ -1159,13 +1141,13 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
         {
           org.apache.thrift.protocol.TMap _map93 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I64, iprot.readI32());
           struct.stageCounters = new HashMap<String,Long>(2*_map93.size);
-          for (int _i94 = 0; _i94 < _map93.size; ++_i94)
+          String _key94;
+          long _val95;
+          for (int _i96 = 0; _i96 < _map93.size; ++_i96)
           {
-            String _key95; // required
-            long _val96; // required
-            _key95 = iprot.readString();
-            _val96 = iprot.readI64();
-            struct.stageCounters.put(_key95, _val96);
+            _key94 = iprot.readString();
+            _val95 = iprot.readI64();
+            struct.stageCounters.put(_key94, _val95);
           }
         }
         struct.setStageCountersIsSet(true);
@@ -1174,12 +1156,12 @@ public class Stage implements org.apache.thrift.TBase<Stage, Stage._Fields>, jav
         {
           org.apache.thrift.protocol.TList _list97 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.taskList = new ArrayList<Task>(_list97.size);
-          for (int _i98 = 0; _i98 < _list97.size; ++_i98)
+          Task _elem98;
+          for (int _i99 = 0; _i99 < _list97.size; ++_i99)
           {
-            Task _elem99; // required
-            _elem99 = new Task();
-            _elem99.read(iprot);
-            struct.taskList.add(_elem99);
+            _elem98 = new Task();
+            _elem98.read(iprot);
+            struct.taskList.add(_elem98);
           }
         }
         struct.setTaskListIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/StageType.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/StageType.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/StageType.java
index 3648273..c7b0ff7 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/StageType.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/StageType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Task.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Task.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Task.java
index fc4313f..e9e3166 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Task.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/Task.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.ql.plan.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.io.Serializable, Cloneable, Comparable<Task> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Task");
 
   private static final org.apache.thrift.protocol.TField TASK_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("taskId", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -145,7 +149,7 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
   private static final int __DONE_ISSET_ID = 0;
   private static final int __STARTED_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.OPERATOR_GRAPH,_Fields.OPERATOR_LIST};
+  private static final _Fields optionals[] = {_Fields.OPERATOR_GRAPH,_Fields.OPERATOR_LIST};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -208,40 +212,18 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
       this.taskType = other.taskType;
     }
     if (other.isSetTaskAttributes()) {
-      Map<String,String> __this__taskAttributes = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.taskAttributes.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__taskAttributes_copy_key = other_element_key;
-
-        String __this__taskAttributes_copy_value = other_element_value;
-
-        __this__taskAttributes.put(__this__taskAttributes_copy_key, __this__taskAttributes_copy_value);
-      }
+      Map<String,String> __this__taskAttributes = new HashMap<String,String>(other.taskAttributes);
       this.taskAttributes = __this__taskAttributes;
     }
     if (other.isSetTaskCounters()) {
-      Map<String,Long> __this__taskCounters = new HashMap<String,Long>();
-      for (Map.Entry<String, Long> other_element : other.taskCounters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        Long other_element_value = other_element.getValue();
-
-        String __this__taskCounters_copy_key = other_element_key;
-
-        Long __this__taskCounters_copy_value = other_element_value;
-
-        __this__taskCounters.put(__this__taskCounters_copy_key, __this__taskCounters_copy_value);
-      }
+      Map<String,Long> __this__taskCounters = new HashMap<String,Long>(other.taskCounters);
       this.taskCounters = __this__taskCounters;
     }
     if (other.isSetOperatorGraph()) {
       this.operatorGraph = new Graph(other.operatorGraph);
     }
     if (other.isSetOperatorList()) {
-      List<Operator> __this__operatorList = new ArrayList<Operator>();
+      List<Operator> __this__operatorList = new ArrayList<Operator>(other.operatorList.size());
       for (Operator other_element : other.operatorList) {
         __this__operatorList.add(new Operator(other_element));
       }
@@ -712,135 +694,135 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_taskId = true && (isSetTaskId());
-    builder.append(present_taskId);
+    list.add(present_taskId);
     if (present_taskId)
-      builder.append(taskId);
+      list.add(taskId);
 
     boolean present_taskType = true && (isSetTaskType());
-    builder.append(present_taskType);
+    list.add(present_taskType);
     if (present_taskType)
-      builder.append(taskType.getValue());
+      list.add(taskType.getValue());
 
     boolean present_taskAttributes = true && (isSetTaskAttributes());
-    builder.append(present_taskAttributes);
+    list.add(present_taskAttributes);
     if (present_taskAttributes)
-      builder.append(taskAttributes);
+      list.add(taskAttributes);
 
     boolean present_taskCounters = true && (isSetTaskCounters());
-    builder.append(present_taskCounters);
+    list.add(present_taskCounters);
     if (present_taskCounters)
-      builder.append(taskCounters);
+      list.add(taskCounters);
 
     boolean present_operatorGraph = true && (isSetOperatorGraph());
-    builder.append(present_operatorGraph);
+    list.add(present_operatorGraph);
     if (present_operatorGraph)
-      builder.append(operatorGraph);
+      list.add(operatorGraph);
 
     boolean present_operatorList = true && (isSetOperatorList());
-    builder.append(present_operatorList);
+    list.add(present_operatorList);
     if (present_operatorList)
-      builder.append(operatorList);
+      list.add(operatorList);
 
     boolean present_done = true;
-    builder.append(present_done);
+    list.add(present_done);
     if (present_done)
-      builder.append(done);
+      list.add(done);
 
     boolean present_started = true;
-    builder.append(present_started);
+    list.add(present_started);
     if (present_started)
-      builder.append(started);
+      list.add(started);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Task other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Task typedOther = (Task)other;
 
-    lastComparison = Boolean.valueOf(isSetTaskId()).compareTo(typedOther.isSetTaskId());
+    lastComparison = Boolean.valueOf(isSetTaskId()).compareTo(other.isSetTaskId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskId, typedOther.taskId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskId, other.taskId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTaskType()).compareTo(typedOther.isSetTaskType());
+    lastComparison = Boolean.valueOf(isSetTaskType()).compareTo(other.isSetTaskType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskType, typedOther.taskType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskType, other.taskType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTaskAttributes()).compareTo(typedOther.isSetTaskAttributes());
+    lastComparison = Boolean.valueOf(isSetTaskAttributes()).compareTo(other.isSetTaskAttributes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskAttributes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskAttributes, typedOther.taskAttributes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskAttributes, other.taskAttributes);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTaskCounters()).compareTo(typedOther.isSetTaskCounters());
+    lastComparison = Boolean.valueOf(isSetTaskCounters()).compareTo(other.isSetTaskCounters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTaskCounters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskCounters, typedOther.taskCounters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.taskCounters, other.taskCounters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperatorGraph()).compareTo(typedOther.isSetOperatorGraph());
+    lastComparison = Boolean.valueOf(isSetOperatorGraph()).compareTo(other.isSetOperatorGraph());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorGraph()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorGraph, typedOther.operatorGraph);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorGraph, other.operatorGraph);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperatorList()).compareTo(typedOther.isSetOperatorList());
+    lastComparison = Boolean.valueOf(isSetOperatorList()).compareTo(other.isSetOperatorList());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperatorList()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorList, typedOther.operatorList);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operatorList, other.operatorList);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDone()).compareTo(typedOther.isSetDone());
+    lastComparison = Boolean.valueOf(isSetDone()).compareTo(other.isSetDone());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDone()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, typedOther.done);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.done, other.done);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(typedOther.isSetStarted());
+    lastComparison = Boolean.valueOf(isSetStarted()).compareTo(other.isSetStarted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStarted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, typedOther.started);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.started, other.started);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -982,7 +964,7 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
             break;
           case 2: // TASK_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.taskType = TaskType.findByValue(iprot.readI32());
+              struct.taskType = org.apache.hadoop.hive.ql.plan.api.TaskType.findByValue(iprot.readI32());
               struct.setTaskTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -993,13 +975,13 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
               {
                 org.apache.thrift.protocol.TMap _map44 = iprot.readMapBegin();
                 struct.taskAttributes = new HashMap<String,String>(2*_map44.size);
-                for (int _i45 = 0; _i45 < _map44.size; ++_i45)
+                String _key45;
+                String _val46;
+                for (int _i47 = 0; _i47 < _map44.size; ++_i47)
                 {
-                  String _key46; // required
-                  String _val47; // required
-                  _key46 = iprot.readString();
-                  _val47 = iprot.readString();
-                  struct.taskAttributes.put(_key46, _val47);
+                  _key45 = iprot.readString();
+                  _val46 = iprot.readString();
+                  struct.taskAttributes.put(_key45, _val46);
                 }
                 iprot.readMapEnd();
               }
@@ -1013,13 +995,13 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
               {
                 org.apache.thrift.protocol.TMap _map48 = iprot.readMapBegin();
                 struct.taskCounters = new HashMap<String,Long>(2*_map48.size);
-                for (int _i49 = 0; _i49 < _map48.size; ++_i49)
+                String _key49;
+                long _val50;
+                for (int _i51 = 0; _i51 < _map48.size; ++_i51)
                 {
-                  String _key50; // required
-                  long _val51; // required
-                  _key50 = iprot.readString();
-                  _val51 = iprot.readI64();
-                  struct.taskCounters.put(_key50, _val51);
+                  _key49 = iprot.readString();
+                  _val50 = iprot.readI64();
+                  struct.taskCounters.put(_key49, _val50);
                 }
                 iprot.readMapEnd();
               }
@@ -1042,12 +1024,12 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
               {
                 org.apache.thrift.protocol.TList _list52 = iprot.readListBegin();
                 struct.operatorList = new ArrayList<Operator>(_list52.size);
-                for (int _i53 = 0; _i53 < _list52.size; ++_i53)
+                Operator _elem53;
+                for (int _i54 = 0; _i54 < _list52.size; ++_i54)
                 {
-                  Operator _elem54; // required
-                  _elem54 = new Operator();
-                  _elem54.read(iprot);
-                  struct.operatorList.add(_elem54);
+                  _elem53 = new Operator();
+                  _elem53.read(iprot);
+                  struct.operatorList.add(_elem53);
                 }
                 iprot.readListEnd();
               }
@@ -1246,20 +1228,20 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
         struct.setTaskIdIsSet(true);
       }
       if (incoming.get(1)) {
-        struct.taskType = TaskType.findByValue(iprot.readI32());
+        struct.taskType = org.apache.hadoop.hive.ql.plan.api.TaskType.findByValue(iprot.readI32());
         struct.setTaskTypeIsSet(true);
       }
       if (incoming.get(2)) {
         {
           org.apache.thrift.protocol.TMap _map61 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.taskAttributes = new HashMap<String,String>(2*_map61.size);
-          for (int _i62 = 0; _i62 < _map61.size; ++_i62)
+          String _key62;
+          String _val63;
+          for (int _i64 = 0; _i64 < _map61.size; ++_i64)
           {
-            String _key63; // required
-            String _val64; // required
-            _key63 = iprot.readString();
-            _val64 = iprot.readString();
-            struct.taskAttributes.put(_key63, _val64);
+            _key62 = iprot.readString();
+            _val63 = iprot.readString();
+            struct.taskAttributes.put(_key62, _val63);
           }
         }
         struct.setTaskAttributesIsSet(true);
@@ -1268,13 +1250,13 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
         {
           org.apache.thrift.protocol.TMap _map65 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I64, iprot.readI32());
           struct.taskCounters = new HashMap<String,Long>(2*_map65.size);
-          for (int _i66 = 0; _i66 < _map65.size; ++_i66)
+          String _key66;
+          long _val67;
+          for (int _i68 = 0; _i68 < _map65.size; ++_i68)
           {
-            String _key67; // required
-            long _val68; // required
-            _key67 = iprot.readString();
-            _val68 = iprot.readI64();
-            struct.taskCounters.put(_key67, _val68);
+            _key66 = iprot.readString();
+            _val67 = iprot.readI64();
+            struct.taskCounters.put(_key66, _val67);
           }
         }
         struct.setTaskCountersIsSet(true);
@@ -1288,12 +1270,12 @@ public class Task implements org.apache.thrift.TBase<Task, Task._Fields>, java.i
         {
           org.apache.thrift.protocol.TList _list69 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.operatorList = new ArrayList<Operator>(_list69.size);
-          for (int _i70 = 0; _i70 < _list69.size; ++_i70)
+          Operator _elem70;
+          for (int _i71 = 0; _i71 < _list69.size; ++_i71)
           {
-            Operator _elem71; // required
-            _elem71 = new Operator();
-            _elem71.read(iprot);
-            struct.operatorList.add(_elem71);
+            _elem70 = new Operator();
+            _elem70.read(iprot);
+            struct.operatorList.add(_elem70);
           }
         }
         struct.setOperatorListIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/TaskType.java
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/TaskType.java b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/TaskType.java
index 7df0029..8aad073 100644
--- a/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/TaskType.java
+++ b/ql/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/ql/plan/api/TaskType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-php/Types.php
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-php/Types.php b/ql/src/gen/thrift/gen-php/Types.php
index 7121ed4..3dfff1d 100644
--- a/ql/src/gen/thrift/gen-php/Types.php
+++ b/ql/src/gen/thrift/gen-php/Types.php
@@ -2,7 +2,7 @@
 namespace ;
 
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -13,6 +13,7 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
@@ -60,6 +61,7 @@ final class OperatorType {
   const ORCFILEMERGE = 22;
   const RCFILEMERGE = 23;
   const MERGEJOIN = 24;
+  const SPARKPRUNINGSINK = 25;
   static public $__names = array(
     0 => 'JOIN',
     1 => 'MAPJOIN',
@@ -86,6 +88,7 @@ final class OperatorType {
     22 => 'ORCFILEMERGE',
     23 => 'RCFILEMERGE',
     24 => 'MERGEJOIN',
+    25 => 'SPARKPRUNINGSINK',
   );
 }
 
@@ -132,8 +135,17 @@ final class StageType {
 class Adjacency {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $node = null;
+  /**
+   * @var string[]
+   */
   public $children = null;
+  /**
+   * @var int
+   */
   public $adjacencyType = null;
 
   public function __construct($vals=null) {
@@ -270,8 +282,17 @@ class Adjacency {
 class Graph {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $nodeType = null;
+  /**
+   * @var string[]
+   */
   public $roots = null;
+  /**
+   * @var \Adjacency[]
+   */
   public $adjacencyList = null;
 
   public function __construct($vals=null) {
@@ -436,11 +457,29 @@ class Graph {
 class Operator {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $operatorId = null;
+  /**
+   * @var int
+   */
   public $operatorType = null;
+  /**
+   * @var array
+   */
   public $operatorAttributes = null;
+  /**
+   * @var array
+   */
   public $operatorCounters = null;
+  /**
+   * @var bool
+   */
   public $done = null;
+  /**
+   * @var bool
+   */
   public $started = null;
 
   public function __construct($vals=null) {
@@ -676,13 +715,37 @@ class Operator {
 class Task {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $taskId = null;
+  /**
+   * @var int
+   */
   public $taskType = null;
+  /**
+   * @var array
+   */
   public $taskAttributes = null;
+  /**
+   * @var array
+   */
   public $taskCounters = null;
+  /**
+   * @var \Graph
+   */
   public $operatorGraph = null;
+  /**
+   * @var \Operator[]
+   */
   public $operatorList = null;
+  /**
+   * @var bool
+   */
   public $done = null;
+  /**
+   * @var bool
+   */
   public $started = null;
 
   public function __construct($vals=null) {
@@ -989,12 +1052,33 @@ class Task {
 class Stage {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $stageId = null;
+  /**
+   * @var int
+   */
   public $stageType = null;
+  /**
+   * @var array
+   */
   public $stageAttributes = null;
+  /**
+   * @var array
+   */
   public $stageCounters = null;
+  /**
+   * @var \Task[]
+   */
   public $taskList = null;
+  /**
+   * @var bool
+   */
   public $done = null;
+  /**
+   * @var bool
+   */
   public $started = null;
 
   public function __construct($vals=null) {
@@ -1277,13 +1361,37 @@ class Stage {
 class Query {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $queryId = null;
+  /**
+   * @var string
+   */
   public $queryType = null;
+  /**
+   * @var array
+   */
   public $queryAttributes = null;
+  /**
+   * @var array
+   */
   public $queryCounters = null;
+  /**
+   * @var \Graph
+   */
   public $stageGraph = null;
+  /**
+   * @var \Stage[]
+   */
   public $stageList = null;
+  /**
+   * @var bool
+   */
   public $done = null;
+  /**
+   * @var bool
+   */
   public $started = null;
 
   public function __construct($vals=null) {
@@ -1590,8 +1698,17 @@ class Query {
 class QueryPlan {
   static $_TSPEC;
 
+  /**
+   * @var \Query[]
+   */
   public $queries = null;
+  /**
+   * @var bool
+   */
   public $done = null;
+  /**
+   * @var bool
+   */
   public $started = null;
 
   public function __construct($vals=null) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-py/queryplan/constants.py
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-py/queryplan/constants.py b/ql/src/gen/thrift/gen-py/queryplan/constants.py
index a236326..99717a9 100644
--- a/ql/src/gen/thrift/gen-py/queryplan/constants.py
+++ b/ql/src/gen/thrift/gen-py/queryplan/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-py/queryplan/ttypes.py
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-py/queryplan/ttypes.py b/ql/src/gen/thrift/gen-py/queryplan/ttypes.py
index 53c0106..6deb850 100644
--- a/ql/src/gen/thrift/gen-py/queryplan/ttypes.py
+++ b/ql/src/gen/thrift/gen-py/queryplan/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -70,6 +70,7 @@ class OperatorType:
   ORCFILEMERGE = 22
   RCFILEMERGE = 23
   MERGEJOIN = 24
+  SPARKPRUNINGSINK = 25
 
   _VALUES_TO_NAMES = {
     0: "JOIN",
@@ -97,6 +98,7 @@ class OperatorType:
     22: "ORCFILEMERGE",
     23: "RCFILEMERGE",
     24: "MERGEJOIN",
+    25: "SPARKPRUNINGSINK",
   }
 
   _NAMES_TO_VALUES = {
@@ -125,6 +127,7 @@ class OperatorType:
     "ORCFILEMERGE": 22,
     "RCFILEMERGE": 23,
     "MERGEJOIN": 24,
+    "SPARKPRUNINGSINK": 25,
   }
 
 class TaskType:
@@ -270,6 +273,13 @@ class Adjacency:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.node)
+    value = (value * 31) ^ hash(self.children)
+    value = (value * 31) ^ hash(self.adjacencyType)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -371,6 +381,13 @@ class Graph:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.nodeType)
+    value = (value * 31) ^ hash(self.roots)
+    value = (value * 31) ^ hash(self.adjacencyList)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -433,7 +450,7 @@ class Operator:
       elif fid == 3:
         if ftype == TType.MAP:
           self.operatorAttributes = {}
-          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin() 
+          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin()
           for _i25 in xrange(_size21):
             _key26 = iprot.readString();
             _val27 = iprot.readString();
@@ -444,7 +461,7 @@ class Operator:
       elif fid == 4:
         if ftype == TType.MAP:
           self.operatorCounters = {}
-          (_ktype29, _vtype30, _size28 ) = iprot.readMapBegin() 
+          (_ktype29, _vtype30, _size28 ) = iprot.readMapBegin()
           for _i32 in xrange(_size28):
             _key33 = iprot.readString();
             _val34 = iprot.readI64();
@@ -511,6 +528,16 @@ class Operator:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.operatorId)
+    value = (value * 31) ^ hash(self.operatorType)
+    value = (value * 31) ^ hash(self.operatorAttributes)
+    value = (value * 31) ^ hash(self.operatorCounters)
+    value = (value * 31) ^ hash(self.done)
+    value = (value * 31) ^ hash(self.started)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -579,7 +606,7 @@ class Task:
       elif fid == 3:
         if ftype == TType.MAP:
           self.taskAttributes = {}
-          (_ktype40, _vtype41, _size39 ) = iprot.readMapBegin() 
+          (_ktype40, _vtype41, _size39 ) = iprot.readMapBegin()
           for _i43 in xrange(_size39):
             _key44 = iprot.readString();
             _val45 = iprot.readString();
@@ -590,7 +617,7 @@ class Task:
       elif fid == 4:
         if ftype == TType.MAP:
           self.taskCounters = {}
-          (_ktype47, _vtype48, _size46 ) = iprot.readMapBegin() 
+          (_ktype47, _vtype48, _size46 ) = iprot.readMapBegin()
           for _i50 in xrange(_size46):
             _key51 = iprot.readString();
             _val52 = iprot.readI64();
@@ -685,6 +712,18 @@ class Task:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.taskId)
+    value = (value * 31) ^ hash(self.taskType)
+    value = (value * 31) ^ hash(self.taskAttributes)
+    value = (value * 31) ^ hash(self.taskCounters)
+    value = (value * 31) ^ hash(self.operatorGraph)
+    value = (value * 31) ^ hash(self.operatorList)
+    value = (value * 31) ^ hash(self.done)
+    value = (value * 31) ^ hash(self.started)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -750,7 +789,7 @@ class Stage:
       elif fid == 3:
         if ftype == TType.MAP:
           self.stageAttributes = {}
-          (_ktype65, _vtype66, _size64 ) = iprot.readMapBegin() 
+          (_ktype65, _vtype66, _size64 ) = iprot.readMapBegin()
           for _i68 in xrange(_size64):
             _key69 = iprot.readString();
             _val70 = iprot.readString();
@@ -761,7 +800,7 @@ class Stage:
       elif fid == 4:
         if ftype == TType.MAP:
           self.stageCounters = {}
-          (_ktype72, _vtype73, _size71 ) = iprot.readMapBegin() 
+          (_ktype72, _vtype73, _size71 ) = iprot.readMapBegin()
           for _i75 in xrange(_size71):
             _key76 = iprot.readString();
             _val77 = iprot.readI64();
@@ -846,6 +885,17 @@ class Stage:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.stageId)
+    value = (value * 31) ^ hash(self.stageType)
+    value = (value * 31) ^ hash(self.stageAttributes)
+    value = (value * 31) ^ hash(self.stageCounters)
+    value = (value * 31) ^ hash(self.taskList)
+    value = (value * 31) ^ hash(self.done)
+    value = (value * 31) ^ hash(self.started)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -914,7 +964,7 @@ class Query:
       elif fid == 3:
         if ftype == TType.MAP:
           self.queryAttributes = {}
-          (_ktype90, _vtype91, _size89 ) = iprot.readMapBegin() 
+          (_ktype90, _vtype91, _size89 ) = iprot.readMapBegin()
           for _i93 in xrange(_size89):
             _key94 = iprot.readString();
             _val95 = iprot.readString();
@@ -925,7 +975,7 @@ class Query:
       elif fid == 4:
         if ftype == TType.MAP:
           self.queryCounters = {}
-          (_ktype97, _vtype98, _size96 ) = iprot.readMapBegin() 
+          (_ktype97, _vtype98, _size96 ) = iprot.readMapBegin()
           for _i100 in xrange(_size96):
             _key101 = iprot.readString();
             _val102 = iprot.readI64();
@@ -1020,6 +1070,18 @@ class Query:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.queryId)
+    value = (value * 31) ^ hash(self.queryType)
+    value = (value * 31) ^ hash(self.queryAttributes)
+    value = (value * 31) ^ hash(self.queryCounters)
+    value = (value * 31) ^ hash(self.stageGraph)
+    value = (value * 31) ^ hash(self.stageList)
+    value = (value * 31) ^ hash(self.done)
+    value = (value * 31) ^ hash(self.started)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1113,6 +1175,13 @@ class QueryPlan:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.queries)
+    value = (value * 31) ^ hash(self.done)
+    value = (value * 31) ^ hash(self.started)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]


[16/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MiniStruct.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MiniStruct.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MiniStruct.java
index b1d3946..c94819a 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MiniStruct.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MiniStruct.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruct._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruct._Fields>, java.io.Serializable, Cloneable, Comparable<MiniStruct> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MiniStruct");
 
   private static final org.apache.thrift.protocol.TField MY_STRING_FIELD_DESC = new org.apache.thrift.protocol.TField("my_string", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -112,7 +116,7 @@ public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruc
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.MY_STRING,_Fields.MY_ENUM};
+  private static final _Fields optionals[] = {_Fields.MY_STRING,_Fields.MY_ENUM};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -287,45 +291,45 @@ public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_my_string = true && (isSetMy_string());
-    builder.append(present_my_string);
+    list.add(present_my_string);
     if (present_my_string)
-      builder.append(my_string);
+      list.add(my_string);
 
     boolean present_my_enum = true && (isSetMy_enum());
-    builder.append(present_my_enum);
+    list.add(present_my_enum);
     if (present_my_enum)
-      builder.append(my_enum.getValue());
+      list.add(my_enum.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(MiniStruct other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    MiniStruct typedOther = (MiniStruct)other;
 
-    lastComparison = Boolean.valueOf(isSetMy_string()).compareTo(typedOther.isSetMy_string());
+    lastComparison = Boolean.valueOf(isSetMy_string()).compareTo(other.isSetMy_string());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_string()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string, typedOther.my_string);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string, other.my_string);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enum()).compareTo(typedOther.isSetMy_enum());
+    lastComparison = Boolean.valueOf(isSetMy_enum()).compareTo(other.isSetMy_enum());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enum()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum, typedOther.my_enum);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum, other.my_enum);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -422,7 +426,7 @@ public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruc
             break;
           case 2: // MY_ENUM
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.my_enum = MyEnum.findByValue(iprot.readI32());
+              struct.my_enum = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
               struct.setMy_enumIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -497,7 +501,7 @@ public class MiniStruct implements org.apache.thrift.TBase<MiniStruct, MiniStruc
         struct.setMy_stringIsSet(true);
       }
       if (incoming.get(1)) {
-        struct.my_enum = MyEnum.findByValue(iprot.readI32());
+        struct.my_enum = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
         struct.setMy_enumIsSet(true);
       }
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MyEnum.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MyEnum.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MyEnum.java
index 5bda9cc..03f88c5 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MyEnum.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MyEnum.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/PropValueUnion.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/PropValueUnion.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/PropValueUnion.java
index a50a508..2a70482 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/PropValueUnion.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/PropValueUnion.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, PropValueUnion._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PropValueUnion");
   private static final org.apache.thrift.protocol.TField INT_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("intValue", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -298,11 +301,11 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
             {
               org.apache.thrift.protocol.TList _list0 = iprot.readListBegin();
               lString = new ArrayList<String>(_list0.size);
-              for (int _i1 = 0; _i1 < _list0.size; ++_i1)
+              String _elem1;
+              for (int _i2 = 0; _i2 < _list0.size; ++_i2)
               {
-                String _elem2; // optional
-                _elem2 = iprot.readString();
-                lString.add(_elem2);
+                _elem1 = iprot.readString();
+                lString.add(_elem1);
               }
               iprot.readListEnd();
             }
@@ -317,13 +320,13 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
             {
               org.apache.thrift.protocol.TMap _map3 = iprot.readMapBegin();
               unionMStringString = new HashMap<String,String>(2*_map3.size);
-              for (int _i4 = 0; _i4 < _map3.size; ++_i4)
+              String _key4;
+              String _val5;
+              for (int _i6 = 0; _i6 < _map3.size; ++_i6)
               {
-                String _key5; // required
-                String _val6; // required
-                _key5 = iprot.readString();
-                _val6 = iprot.readString();
-                unionMStringString.put(_key5, _val6);
+                _key4 = iprot.readString();
+                _val5 = iprot.readString();
+                unionMStringString.put(_key4, _val5);
               }
               iprot.readMapEnd();
             }
@@ -336,6 +339,7 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -421,11 +425,11 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
           {
             org.apache.thrift.protocol.TList _list9 = iprot.readListBegin();
             lString = new ArrayList<String>(_list9.size);
-            for (int _i10 = 0; _i10 < _list9.size; ++_i10)
+            String _elem10;
+            for (int _i11 = 0; _i11 < _list9.size; ++_i11)
             {
-              String _elem11; // optional
-              _elem11 = iprot.readString();
-              lString.add(_elem11);
+              _elem10 = iprot.readString();
+              lString.add(_elem10);
             }
             iprot.readListEnd();
           }
@@ -435,13 +439,13 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
           {
             org.apache.thrift.protocol.TMap _map12 = iprot.readMapBegin();
             unionMStringString = new HashMap<String,String>(2*_map12.size);
-            for (int _i13 = 0; _i13 < _map12.size; ++_i13)
+            String _key13;
+            String _val14;
+            for (int _i15 = 0; _i15 < _map12.size; ++_i15)
             {
-              String _key14; // required
-              String _val15; // required
-              _key14 = iprot.readString();
-              _val15 = iprot.readString();
-              unionMStringString.put(_key14, _val15);
+              _key13 = iprot.readString();
+              _val14 = iprot.readString();
+              unionMStringString.put(_key13, _val14);
             }
             iprot.readMapEnd();
           }
@@ -695,19 +699,19 @@ public class PropValueUnion extends org.apache.thrift.TUnion<PropValueUnion, Pro
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/SetIntString.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/SetIntString.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/SetIntString.java
index 334d225..e3795af 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/SetIntString.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/SetIntString.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIntString._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIntString._Fields>, java.io.Serializable, Cloneable, Comparable<SetIntString> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("SetIntString");
 
   private static final org.apache.thrift.protocol.TField S_INT_STRING_FIELD_DESC = new org.apache.thrift.protocol.TField("sIntString", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -137,7 +141,7 @@ public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIn
    */
   public SetIntString(SetIntString other) {
     if (other.isSetSIntString()) {
-      Set<IntString> __this__sIntString = new HashSet<IntString>();
+      Set<IntString> __this__sIntString = new HashSet<IntString>(other.sIntString.size());
       for (IntString other_element : other.sIntString) {
         __this__sIntString.add(new IntString(other_element));
       }
@@ -303,45 +307,45 @@ public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIn
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sIntString = true && (isSetSIntString());
-    builder.append(present_sIntString);
+    list.add(present_sIntString);
     if (present_sIntString)
-      builder.append(sIntString);
+      list.add(sIntString);
 
     boolean present_aString = true && (isSetAString());
-    builder.append(present_aString);
+    list.add(present_aString);
     if (present_aString)
-      builder.append(aString);
+      list.add(aString);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(SetIntString other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    SetIntString typedOther = (SetIntString)other;
 
-    lastComparison = Boolean.valueOf(isSetSIntString()).compareTo(typedOther.isSetSIntString());
+    lastComparison = Boolean.valueOf(isSetSIntString()).compareTo(other.isSetSIntString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSIntString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sIntString, typedOther.sIntString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sIntString, other.sIntString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAString()).compareTo(typedOther.isSetAString());
+    lastComparison = Boolean.valueOf(isSetAString()).compareTo(other.isSetAString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aString, typedOther.aString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aString, other.aString);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -429,12 +433,12 @@ public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIn
               {
                 org.apache.thrift.protocol.TSet _set82 = iprot.readSetBegin();
                 struct.sIntString = new HashSet<IntString>(2*_set82.size);
-                for (int _i83 = 0; _i83 < _set82.size; ++_i83)
+                IntString _elem83;
+                for (int _i84 = 0; _i84 < _set82.size; ++_i84)
                 {
-                  IntString _elem84; // optional
-                  _elem84 = new IntString();
-                  _elem84.read(iprot);
-                  struct.sIntString.add(_elem84);
+                  _elem83 = new IntString();
+                  _elem83.read(iprot);
+                  struct.sIntString.add(_elem83);
                 }
                 iprot.readSetEnd();
               }
@@ -528,12 +532,12 @@ public class SetIntString implements org.apache.thrift.TBase<SetIntString, SetIn
         {
           org.apache.thrift.protocol.TSet _set87 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.sIntString = new HashSet<IntString>(2*_set87.size);
-          for (int _i88 = 0; _i88 < _set87.size; ++_i88)
+          IntString _elem88;
+          for (int _i89 = 0; _i89 < _set87.size; ++_i89)
           {
-            IntString _elem89; // optional
-            _elem89 = new IntString();
-            _elem89.read(iprot);
-            struct.sIntString.add(_elem89);
+            _elem88 = new IntString();
+            _elem88.read(iprot);
+            struct.sIntString.add(_elem88);
           }
         }
         struct.setSIntStringIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-php/Types.php
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-php/Types.php b/serde/src/gen/thrift/gen-php/Types.php
index 8c2cea6..8bb2fe3 100644
--- a/serde/src/gen/thrift/gen-php/Types.php
+++ b/serde/src/gen/thrift/gen-php/Types.php
@@ -2,7 +2,7 @@
 namespace ;
 
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -13,12 +13,16 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
 class InnerStruct {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $field0 = null;
 
   public function __construct($vals=null) {
@@ -91,8 +95,17 @@ class InnerStruct {
 class ThriftTestObj {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $field1 = null;
+  /**
+   * @var string
+   */
   public $field2 = null;
+  /**
+   * @var \InnerStruct[]
+   */
   public $field3 = null;
 
   public function __construct($vals=null) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-php/org/apache/hadoop/hive/serde/Types.php
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-php/org/apache/hadoop/hive/serde/Types.php b/serde/src/gen/thrift/gen-php/org/apache/hadoop/hive/serde/Types.php
index 653662a..2475cc8 100644
--- a/serde/src/gen/thrift/gen-php/org/apache/hadoop/hive/serde/Types.php
+++ b/serde/src/gen/thrift/gen-php/org/apache/hadoop/hive/serde/Types.php
@@ -2,7 +2,7 @@
 namespace org\apache\hadoop\hive\serde;
 
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -13,124 +13,263 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_LIB'] = "serialization.lib";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_CLASS'] = "serialization.class";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_FORMAT'] = "serialization.format";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_DDL'] = "serialization.ddl";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_NULL_FORMAT'] = "serialization.null.format";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_LAST_COLUMN_TAKES_REST'] = "serialization.last.column.takes.rest";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_SORT_ORDER'] = "serialization.sort.order";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_USE_JSON_OBJECTS'] = "serialization.use.json.object";
-
-$GLOBALS['serde_CONSTANTS']['SERIALIZATION_ENCODING'] = "serialization.encoding";
-
-$GLOBALS['serde_CONSTANTS']['FIELD_DELIM'] = "field.delim";
-
-$GLOBALS['serde_CONSTANTS']['COLLECTION_DELIM'] = "colelction.delim";
-
-$GLOBALS['serde_CONSTANTS']['LINE_DELIM'] = "line.delim";
-
-$GLOBALS['serde_CONSTANTS']['MAPKEY_DELIM'] = "mapkey.delim";
-
-$GLOBALS['serde_CONSTANTS']['QUOTE_CHAR'] = "quote.delim";
-
-$GLOBALS['serde_CONSTANTS']['ESCAPE_CHAR'] = "escape.delim";
-
-$GLOBALS['serde_CONSTANTS']['HEADER_COUNT'] = "skip.header.line.count";
-
-$GLOBALS['serde_CONSTANTS']['FOOTER_COUNT'] = "skip.footer.line.count";
-
-$GLOBALS['serde_CONSTANTS']['VOID_TYPE_NAME'] = "void";
-
-$GLOBALS['serde_CONSTANTS']['BOOLEAN_TYPE_NAME'] = "boolean";
-
-$GLOBALS['serde_CONSTANTS']['TINYINT_TYPE_NAME'] = "tinyint";
-
-$GLOBALS['serde_CONSTANTS']['SMALLINT_TYPE_NAME'] = "smallint";
-
-$GLOBALS['serde_CONSTANTS']['INT_TYPE_NAME'] = "int";
-
-$GLOBALS['serde_CONSTANTS']['BIGINT_TYPE_NAME'] = "bigint";
-
-$GLOBALS['serde_CONSTANTS']['FLOAT_TYPE_NAME'] = "float";
-
-$GLOBALS['serde_CONSTANTS']['DOUBLE_TYPE_NAME'] = "double";
-
-$GLOBALS['serde_CONSTANTS']['STRING_TYPE_NAME'] = "string";
-
-$GLOBALS['serde_CONSTANTS']['CHAR_TYPE_NAME'] = "char";
-
-$GLOBALS['serde_CONSTANTS']['VARCHAR_TYPE_NAME'] = "varchar";
-
-$GLOBALS['serde_CONSTANTS']['DATE_TYPE_NAME'] = "date";
-
-$GLOBALS['serde_CONSTANTS']['DATETIME_TYPE_NAME'] = "datetime";
-
-$GLOBALS['serde_CONSTANTS']['TIMESTAMP_TYPE_NAME'] = "timestamp";
-
-$GLOBALS['serde_CONSTANTS']['DECIMAL_TYPE_NAME'] = "decimal";
-
-$GLOBALS['serde_CONSTANTS']['BINARY_TYPE_NAME'] = "binary";
-
-$GLOBALS['serde_CONSTANTS']['INTERVAL_YEAR_MONTH_TYPE_NAME'] = "interval_year_month";
-
-$GLOBALS['serde_CONSTANTS']['INTERVAL_DAY_TIME_TYPE_NAME'] = "interval_day_time";
-
-$GLOBALS['serde_CONSTANTS']['LIST_TYPE_NAME'] = "array";
-
-$GLOBALS['serde_CONSTANTS']['MAP_TYPE_NAME'] = "map";
-
-$GLOBALS['serde_CONSTANTS']['STRUCT_TYPE_NAME'] = "struct";
-
-$GLOBALS['serde_CONSTANTS']['UNION_TYPE_NAME'] = "uniontype";
-
-$GLOBALS['serde_CONSTANTS']['LIST_COLUMNS'] = "columns";
-
-$GLOBALS['serde_CONSTANTS']['LIST_COLUMN_TYPES'] = "columns.types";
-
-$GLOBALS['serde_CONSTANTS']['TIMESTAMP_FORMATS'] = "timestamp.formats";
-
-$GLOBALS['serde_CONSTANTS']['PrimitiveTypes'] = array(
-  "void" => true,
-  "boolean" => true,
-  "tinyint" => true,
-  "smallint" => true,
-  "int" => true,
-  "bigint" => true,
-  "float" => true,
-  "double" => true,
-  "string" => true,
-  "varchar" => true,
-  "char" => true,
-  "date" => true,
-  "datetime" => true,
-  "timestamp" => true,
-  "interval_year_month" => true,
-  "interval_day_time" => true,
-  "decimal" => true,
-  "binary" => true,
-);
-
-$GLOBALS['serde_CONSTANTS']['CollectionTypes'] = array(
-  "array" => true,
-  "map" => true,
-);
-
-$GLOBALS['serde_CONSTANTS']['IntegralTypes'] = array(
-  "tinyint" => true,
-  "smallint" => true,
-  "int" => true,
-  "bigint" => true,
-);
+final class Constant extends \Thrift\Type\TConstant {
+  static protected $SERIALIZATION_LIB;
+  static protected $SERIALIZATION_CLASS;
+  static protected $SERIALIZATION_FORMAT;
+  static protected $SERIALIZATION_DDL;
+  static protected $SERIALIZATION_NULL_FORMAT;
+  static protected $SERIALIZATION_LAST_COLUMN_TAKES_REST;
+  static protected $SERIALIZATION_SORT_ORDER;
+  static protected $SERIALIZATION_USE_JSON_OBJECTS;
+  static protected $SERIALIZATION_ENCODING;
+  static protected $FIELD_DELIM;
+  static protected $COLLECTION_DELIM;
+  static protected $LINE_DELIM;
+  static protected $MAPKEY_DELIM;
+  static protected $QUOTE_CHAR;
+  static protected $ESCAPE_CHAR;
+  static protected $HEADER_COUNT;
+  static protected $FOOTER_COUNT;
+  static protected $VOID_TYPE_NAME;
+  static protected $BOOLEAN_TYPE_NAME;
+  static protected $TINYINT_TYPE_NAME;
+  static protected $SMALLINT_TYPE_NAME;
+  static protected $INT_TYPE_NAME;
+  static protected $BIGINT_TYPE_NAME;
+  static protected $FLOAT_TYPE_NAME;
+  static protected $DOUBLE_TYPE_NAME;
+  static protected $STRING_TYPE_NAME;
+  static protected $CHAR_TYPE_NAME;
+  static protected $VARCHAR_TYPE_NAME;
+  static protected $DATE_TYPE_NAME;
+  static protected $DATETIME_TYPE_NAME;
+  static protected $TIMESTAMP_TYPE_NAME;
+  static protected $DECIMAL_TYPE_NAME;
+  static protected $BINARY_TYPE_NAME;
+  static protected $INTERVAL_YEAR_MONTH_TYPE_NAME;
+  static protected $INTERVAL_DAY_TIME_TYPE_NAME;
+  static protected $LIST_TYPE_NAME;
+  static protected $MAP_TYPE_NAME;
+  static protected $STRUCT_TYPE_NAME;
+  static protected $UNION_TYPE_NAME;
+  static protected $LIST_COLUMNS;
+  static protected $LIST_COLUMN_TYPES;
+  static protected $TIMESTAMP_FORMATS;
+  static protected $PrimitiveTypes;
+  static protected $CollectionTypes;
+  static protected $IntegralTypes;
+
+  static protected function init_SERIALIZATION_LIB() {
+    return "serialization.lib";
+  }
+
+  static protected function init_SERIALIZATION_CLASS() {
+    return "serialization.class";
+  }
+
+  static protected function init_SERIALIZATION_FORMAT() {
+    return "serialization.format";
+  }
+
+  static protected function init_SERIALIZATION_DDL() {
+    return "serialization.ddl";
+  }
+
+  static protected function init_SERIALIZATION_NULL_FORMAT() {
+    return "serialization.null.format";
+  }
+
+  static protected function init_SERIALIZATION_LAST_COLUMN_TAKES_REST() {
+    return "serialization.last.column.takes.rest";
+  }
+
+  static protected function init_SERIALIZATION_SORT_ORDER() {
+    return "serialization.sort.order";
+  }
+
+  static protected function init_SERIALIZATION_USE_JSON_OBJECTS() {
+    return "serialization.use.json.object";
+  }
+
+  static protected function init_SERIALIZATION_ENCODING() {
+    return "serialization.encoding";
+  }
+
+  static protected function init_FIELD_DELIM() {
+    return "field.delim";
+  }
+
+  static protected function init_COLLECTION_DELIM() {
+    return "colelction.delim";
+  }
+
+  static protected function init_LINE_DELIM() {
+    return "line.delim";
+  }
+
+  static protected function init_MAPKEY_DELIM() {
+    return "mapkey.delim";
+  }
+
+  static protected function init_QUOTE_CHAR() {
+    return "quote.delim";
+  }
+
+  static protected function init_ESCAPE_CHAR() {
+    return "escape.delim";
+  }
+
+  static protected function init_HEADER_COUNT() {
+    return "skip.header.line.count";
+  }
+
+  static protected function init_FOOTER_COUNT() {
+    return "skip.footer.line.count";
+  }
+
+  static protected function init_VOID_TYPE_NAME() {
+    return "void";
+  }
+
+  static protected function init_BOOLEAN_TYPE_NAME() {
+    return "boolean";
+  }
+
+  static protected function init_TINYINT_TYPE_NAME() {
+    return "tinyint";
+  }
+
+  static protected function init_SMALLINT_TYPE_NAME() {
+    return "smallint";
+  }
+
+  static protected function init_INT_TYPE_NAME() {
+    return "int";
+  }
+
+  static protected function init_BIGINT_TYPE_NAME() {
+    return "bigint";
+  }
+
+  static protected function init_FLOAT_TYPE_NAME() {
+    return "float";
+  }
+
+  static protected function init_DOUBLE_TYPE_NAME() {
+    return "double";
+  }
+
+  static protected function init_STRING_TYPE_NAME() {
+    return "string";
+  }
+
+  static protected function init_CHAR_TYPE_NAME() {
+    return "char";
+  }
+
+  static protected function init_VARCHAR_TYPE_NAME() {
+    return "varchar";
+  }
+
+  static protected function init_DATE_TYPE_NAME() {
+    return "date";
+  }
+
+  static protected function init_DATETIME_TYPE_NAME() {
+    return "datetime";
+  }
+
+  static protected function init_TIMESTAMP_TYPE_NAME() {
+    return "timestamp";
+  }
+
+  static protected function init_DECIMAL_TYPE_NAME() {
+    return "decimal";
+  }
+
+  static protected function init_BINARY_TYPE_NAME() {
+    return "binary";
+  }
+
+  static protected function init_INTERVAL_YEAR_MONTH_TYPE_NAME() {
+    return "interval_year_month";
+  }
+
+  static protected function init_INTERVAL_DAY_TIME_TYPE_NAME() {
+    return "interval_day_time";
+  }
+
+  static protected function init_LIST_TYPE_NAME() {
+    return "array";
+  }
+
+  static protected function init_MAP_TYPE_NAME() {
+    return "map";
+  }
+
+  static protected function init_STRUCT_TYPE_NAME() {
+    return "struct";
+  }
+
+  static protected function init_UNION_TYPE_NAME() {
+    return "uniontype";
+  }
+
+  static protected function init_LIST_COLUMNS() {
+    return "columns";
+  }
+
+  static protected function init_LIST_COLUMN_TYPES() {
+    return "columns.types";
+  }
+
+  static protected function init_TIMESTAMP_FORMATS() {
+    return "timestamp.formats";
+  }
+
+  static protected function init_PrimitiveTypes() {
+    return array(
+      "void" => true,
+      "boolean" => true,
+      "tinyint" => true,
+      "smallint" => true,
+      "int" => true,
+      "bigint" => true,
+      "float" => true,
+      "double" => true,
+      "string" => true,
+      "varchar" => true,
+      "char" => true,
+      "date" => true,
+      "datetime" => true,
+      "timestamp" => true,
+      "interval_year_month" => true,
+      "interval_day_time" => true,
+      "decimal" => true,
+      "binary" => true,
+    );
+  }
+
+  static protected function init_CollectionTypes() {
+    return array(
+      "array" => true,
+      "map" => true,
+    );
+  }
+
+  static protected function init_IntegralTypes() {
+    return array(
+      "tinyint" => true,
+      "smallint" => true,
+      "int" => true,
+      "bigint" => true,
+    );
+  }
+}
 
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/complex/constants.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/complex/constants.py b/serde/src/gen/thrift/gen-py/complex/constants.py
index a236326..99717a9 100644
--- a/serde/src/gen/thrift/gen-py/complex/constants.py
+++ b/serde/src/gen/thrift/gen-py/complex/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/complex/ttypes.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/complex/ttypes.py b/serde/src/gen/thrift/gen-py/complex/ttypes.py
index c2748d0..7f757da 100644
--- a/serde/src/gen/thrift/gen-py/complex/ttypes.py
+++ b/serde/src/gen/thrift/gen-py/complex/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -96,7 +96,7 @@ class PropValueUnion:
       elif fid == 7:
         if ftype == TType.MAP:
           self.unionMStringString = {}
-          (_ktype7, _vtype8, _size6 ) = iprot.readMapBegin() 
+          (_ktype7, _vtype8, _size6 ) = iprot.readMapBegin()
           for _i10 in xrange(_size6):
             _key11 = iprot.readString();
             _val12 = iprot.readString();
@@ -156,6 +156,17 @@ class PropValueUnion:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.intValue)
+    value = (value * 31) ^ hash(self.longValue)
+    value = (value * 31) ^ hash(self.stringValue)
+    value = (value * 31) ^ hash(self.doubleValue)
+    value = (value * 31) ^ hash(self.flag)
+    value = (value * 31) ^ hash(self.lString)
+    value = (value * 31) ^ hash(self.unionMStringString)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -240,6 +251,13 @@ class IntString:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.myint)
+    value = (value * 31) ^ hash(self.myString)
+    value = (value * 31) ^ hash(self.underscore_int)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -345,7 +363,7 @@ class Complex:
       elif fid == 6:
         if ftype == TType.MAP:
           self.mStringString = {}
-          (_ktype35, _vtype36, _size34 ) = iprot.readMapBegin() 
+          (_ktype35, _vtype36, _size34 ) = iprot.readMapBegin()
           for _i38 in xrange(_size34):
             _key39 = iprot.readString();
             _val40 = iprot.readString();
@@ -356,15 +374,15 @@ class Complex:
       elif fid == 7:
         if ftype == TType.MAP:
           self.attributes = {}
-          (_ktype42, _vtype43, _size41 ) = iprot.readMapBegin() 
+          (_ktype42, _vtype43, _size41 ) = iprot.readMapBegin()
           for _i45 in xrange(_size41):
             _key46 = iprot.readString();
             _val47 = {}
-            (_ktype49, _vtype50, _size48 ) = iprot.readMapBegin() 
+            (_ktype49, _vtype50, _size48 ) = iprot.readMapBegin()
             for _i52 in xrange(_size48):
               _key53 = iprot.readString();
               _val54 = {}
-              (_ktype56, _vtype57, _size55 ) = iprot.readMapBegin() 
+              (_ktype56, _vtype57, _size55 ) = iprot.readMapBegin()
               for _i59 in xrange(_size55):
                 _key60 = iprot.readString();
                 _val61 = PropValueUnion()
@@ -477,6 +495,20 @@ class Complex:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.aint)
+    value = (value * 31) ^ hash(self.aString)
+    value = (value * 31) ^ hash(self.lint)
+    value = (value * 31) ^ hash(self.lString)
+    value = (value * 31) ^ hash(self.lintString)
+    value = (value * 31) ^ hash(self.mStringString)
+    value = (value * 31) ^ hash(self.attributes)
+    value = (value * 31) ^ hash(self.unionField1)
+    value = (value * 31) ^ hash(self.unionField2)
+    value = (value * 31) ^ hash(self.unionField3)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -558,6 +590,12 @@ class SetIntString:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.sIntString)
+    value = (value * 31) ^ hash(self.aString)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/megastruct/constants.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/megastruct/constants.py b/serde/src/gen/thrift/gen-py/megastruct/constants.py
index a236326..99717a9 100644
--- a/serde/src/gen/thrift/gen-py/megastruct/constants.py
+++ b/serde/src/gen/thrift/gen-py/megastruct/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/megastruct/ttypes.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/megastruct/ttypes.py b/serde/src/gen/thrift/gen-py/megastruct/ttypes.py
index de516b2..c4c5a7f 100644
--- a/serde/src/gen/thrift/gen-py/megastruct/ttypes.py
+++ b/serde/src/gen/thrift/gen-py/megastruct/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -92,6 +92,12 @@ class MiniStruct:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.my_string)
+    value = (value * 31) ^ hash(self.my_enum)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -226,7 +232,7 @@ class MegaStruct:
       elif fid == 9:
         if ftype == TType.MAP:
           self.my_string_string_map = {}
-          (_ktype1, _vtype2, _size0 ) = iprot.readMapBegin() 
+          (_ktype1, _vtype2, _size0 ) = iprot.readMapBegin()
           for _i4 in xrange(_size0):
             _key5 = iprot.readString();
             _val6 = iprot.readString();
@@ -237,7 +243,7 @@ class MegaStruct:
       elif fid == 10:
         if ftype == TType.MAP:
           self.my_string_enum_map = {}
-          (_ktype8, _vtype9, _size7 ) = iprot.readMapBegin() 
+          (_ktype8, _vtype9, _size7 ) = iprot.readMapBegin()
           for _i11 in xrange(_size7):
             _key12 = iprot.readString();
             _val13 = iprot.readI32();
@@ -248,7 +254,7 @@ class MegaStruct:
       elif fid == 11:
         if ftype == TType.MAP:
           self.my_enum_string_map = {}
-          (_ktype15, _vtype16, _size14 ) = iprot.readMapBegin() 
+          (_ktype15, _vtype16, _size14 ) = iprot.readMapBegin()
           for _i18 in xrange(_size14):
             _key19 = iprot.readI32();
             _val20 = iprot.readString();
@@ -259,7 +265,7 @@ class MegaStruct:
       elif fid == 12:
         if ftype == TType.MAP:
           self.my_enum_struct_map = {}
-          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin() 
+          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin()
           for _i25 in xrange(_size21):
             _key26 = iprot.readI32();
             _val27 = MiniStruct()
@@ -271,7 +277,7 @@ class MegaStruct:
       elif fid == 13:
         if ftype == TType.MAP:
           self.my_enum_stringlist_map = {}
-          (_ktype29, _vtype30, _size28 ) = iprot.readMapBegin() 
+          (_ktype29, _vtype30, _size28 ) = iprot.readMapBegin()
           for _i32 in xrange(_size28):
             _key33 = iprot.readI32();
             _val34 = []
@@ -287,7 +293,7 @@ class MegaStruct:
       elif fid == 14:
         if ftype == TType.MAP:
           self.my_enum_structlist_map = {}
-          (_ktype42, _vtype43, _size41 ) = iprot.readMapBegin() 
+          (_ktype42, _vtype43, _size41 ) = iprot.readMapBegin()
           for _i45 in xrange(_size41):
             _key46 = iprot.readI32();
             _val47 = []
@@ -508,6 +514,30 @@ class MegaStruct:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.my_bool)
+    value = (value * 31) ^ hash(self.my_byte)
+    value = (value * 31) ^ hash(self.my_16bit_int)
+    value = (value * 31) ^ hash(self.my_32bit_int)
+    value = (value * 31) ^ hash(self.my_64bit_int)
+    value = (value * 31) ^ hash(self.my_double)
+    value = (value * 31) ^ hash(self.my_string)
+    value = (value * 31) ^ hash(self.my_binary)
+    value = (value * 31) ^ hash(self.my_string_string_map)
+    value = (value * 31) ^ hash(self.my_string_enum_map)
+    value = (value * 31) ^ hash(self.my_enum_string_map)
+    value = (value * 31) ^ hash(self.my_enum_struct_map)
+    value = (value * 31) ^ hash(self.my_enum_stringlist_map)
+    value = (value * 31) ^ hash(self.my_enum_structlist_map)
+    value = (value * 31) ^ hash(self.my_stringlist)
+    value = (value * 31) ^ hash(self.my_structlist)
+    value = (value * 31) ^ hash(self.my_enumlist)
+    value = (value * 31) ^ hash(self.my_stringset)
+    value = (value * 31) ^ hash(self.my_enumset)
+    value = (value * 31) ^ hash(self.my_structset)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/constants.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/constants.py b/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/constants.py
index fa0edc7..27a6cdb 100644
--- a/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/constants.py
+++ b/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/ttypes.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/ttypes.py b/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/ttypes.py
index ad3e280..daa619e 100644
--- a/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/ttypes.py
+++ b/serde/src/gen/thrift/gen-py/org_apache_hadoop_hive_serde/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/testthrift/constants.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/testthrift/constants.py b/serde/src/gen/thrift/gen-py/testthrift/constants.py
index a236326..99717a9 100644
--- a/serde/src/gen/thrift/gen-py/testthrift/constants.py
+++ b/serde/src/gen/thrift/gen-py/testthrift/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-py/testthrift/ttypes.py
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-py/testthrift/ttypes.py b/serde/src/gen/thrift/gen-py/testthrift/ttypes.py
index a8b2224..1b64a7d 100644
--- a/serde/src/gen/thrift/gen-py/testthrift/ttypes.py
+++ b/serde/src/gen/thrift/gen-py/testthrift/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -66,6 +66,11 @@ class InnerStruct:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.field0)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -159,6 +164,13 @@ class ThriftTestObj:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.field1)
+    value = (value * 31) ^ hash(self.field2)
+    value = (value * 31) ^ hash(self.field3)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/complex_constants.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/complex_constants.rb b/serde/src/gen/thrift/gen-rb/complex_constants.rb
index 00ee2e8..3df0b7a 100644
--- a/serde/src/gen/thrift/gen-rb/complex_constants.rb
+++ b/serde/src/gen/thrift/gen-rb/complex_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/complex_types.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/complex_types.rb b/serde/src/gen/thrift/gen-rb/complex_types.rb
index ffbd4d7..13d981f 100644
--- a/serde/src/gen/thrift/gen-rb/complex_types.rb
+++ b/serde/src/gen/thrift/gen-rb/complex_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/megastruct_constants.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/megastruct_constants.rb b/serde/src/gen/thrift/gen-rb/megastruct_constants.rb
index 91193eb..6eb3f07 100644
--- a/serde/src/gen/thrift/gen-rb/megastruct_constants.rb
+++ b/serde/src/gen/thrift/gen-rb/megastruct_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/megastruct_types.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/megastruct_types.rb b/serde/src/gen/thrift/gen-rb/megastruct_types.rb
index c299cf3..7d425af 100644
--- a/serde/src/gen/thrift/gen-rb/megastruct_types.rb
+++ b/serde/src/gen/thrift/gen-rb/megastruct_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/serde_constants.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/serde_constants.rb b/serde/src/gen/thrift/gen-rb/serde_constants.rb
index 1c893c1..2eb4754 100644
--- a/serde/src/gen/thrift/gen-rb/serde_constants.rb
+++ b/serde/src/gen/thrift/gen-rb/serde_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/serde_types.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/serde_types.rb b/serde/src/gen/thrift/gen-rb/serde_types.rb
index d426047..b3143d1 100644
--- a/serde/src/gen/thrift/gen-rb/serde_types.rb
+++ b/serde/src/gen/thrift/gen-rb/serde_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/testthrift_constants.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/testthrift_constants.rb b/serde/src/gen/thrift/gen-rb/testthrift_constants.rb
index 13616ee..1f9473e 100644
--- a/serde/src/gen/thrift/gen-rb/testthrift_constants.rb
+++ b/serde/src/gen/thrift/gen-rb/testthrift_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-rb/testthrift_types.rb
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-rb/testthrift_types.rb b/serde/src/gen/thrift/gen-rb/testthrift_types.rb
index 3f76ae6..80d5572 100644
--- a/serde/src/gen/thrift/gen-rb/testthrift_types.rb
+++ b/serde/src/gen/thrift/gen-rb/testthrift_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #


[09/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolColumn.java
index efd571c..4a02643 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolColumn._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TBoolColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TBoolColumn");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
    */
   public TBoolColumn(TBoolColumn other) {
     if (other.isSetValues()) {
-      List<Boolean> __this__values = new ArrayList<Boolean>();
-      for (Boolean other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Boolean> __this__values = new ArrayList<Boolean>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TBoolColumn other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TBoolColumn typedOther = (TBoolColumn)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
               {
                 org.apache.thrift.protocol.TList _list54 = iprot.readListBegin();
                 struct.values = new ArrayList<Boolean>(_list54.size);
-                for (int _i55 = 0; _i55 < _list54.size; ++_i55)
+                boolean _elem55;
+                for (int _i56 = 0; _i56 < _list54.size; ++_i56)
                 {
-                  boolean _elem56; // optional
-                  _elem56 = iprot.readBool();
-                  struct.values.add(_elem56);
+                  _elem55 = iprot.readBool();
+                  struct.values.add(_elem55);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TBoolColumn implements org.apache.thrift.TBase<TBoolColumn, TBoolCo
       {
         org.apache.thrift.protocol.TList _list59 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.BOOL, iprot.readI32());
         struct.values = new ArrayList<Boolean>(_list59.size);
-        for (int _i60 = 0; _i60 < _list59.size; ++_i60)
+        boolean _elem60;
+        for (int _i61 = 0; _i61 < _list59.size; ++_i61)
         {
-          boolean _elem61; // optional
-          _elem61 = iprot.readBool();
-          struct.values.add(_elem61);
+          _elem60 = iprot.readBool();
+          struct.values.add(_elem60);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolValue.java
index c7495ee..06f3c5f 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBoolValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TBoolValue implements org.apache.thrift.TBase<TBoolValue, TBoolValue._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TBoolValue implements org.apache.thrift.TBase<TBoolValue, TBoolValue._Fields>, java.io.Serializable, Cloneable, Comparable<TBoolValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TBoolValue");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -105,7 +109,7 @@ public class TBoolValue implements org.apache.thrift.TBase<TBoolValue, TBoolValu
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TBoolValue implements org.apache.thrift.TBase<TBoolValue, TBoolValu
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TBoolValue other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TBoolValue typedOther = (TBoolValue)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteColumn.java
index 169bfde..e99d02c 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteColumn._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TByteColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TByteColumn");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
    */
   public TByteColumn(TByteColumn other) {
     if (other.isSetValues()) {
-      List<Byte> __this__values = new ArrayList<Byte>();
-      for (Byte other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Byte> __this__values = new ArrayList<Byte>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TByteColumn other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TByteColumn typedOther = (TByteColumn)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
               {
                 org.apache.thrift.protocol.TList _list62 = iprot.readListBegin();
                 struct.values = new ArrayList<Byte>(_list62.size);
-                for (int _i63 = 0; _i63 < _list62.size; ++_i63)
+                byte _elem63;
+                for (int _i64 = 0; _i64 < _list62.size; ++_i64)
                 {
-                  byte _elem64; // optional
-                  _elem64 = iprot.readByte();
-                  struct.values.add(_elem64);
+                  _elem63 = iprot.readByte();
+                  struct.values.add(_elem63);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TByteColumn implements org.apache.thrift.TBase<TByteColumn, TByteCo
       {
         org.apache.thrift.protocol.TList _list67 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.BYTE, iprot.readI32());
         struct.values = new ArrayList<Byte>(_list67.size);
-        for (int _i68 = 0; _i68 < _list67.size; ++_i68)
+        byte _elem68;
+        for (int _i69 = 0; _i69 < _list67.size; ++_i69)
         {
-          byte _elem69; // optional
-          _elem69 = iprot.readByte();
-          struct.values.add(_elem69);
+          _elem68 = iprot.readByte();
+          struct.values.add(_elem68);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteValue.java
index 23d9693..0ccc5ab 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TByteValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TByteValue implements org.apache.thrift.TBase<TByteValue, TByteValue._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TByteValue implements org.apache.thrift.TBase<TByteValue, TByteValue._Fields>, java.io.Serializable, Cloneable, Comparable<TByteValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TByteValue");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.BYTE, (short)1);
@@ -105,7 +109,7 @@ public class TByteValue implements org.apache.thrift.TBase<TByteValue, TByteValu
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TByteValue implements org.apache.thrift.TBase<TByteValue, TByteValu
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TByteValue other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TByteValue typedOther = (TByteValue)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }


[29/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
old mode 100644
new mode 100755
index 36aced3..55c9679
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ThriftHiveMetastore-remote
@@ -1,6 +1,6 @@
 #!/usr/bin/env python
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -12,141 +12,155 @@ import pprint
 from urlparse import urlparse
 from thrift.transport import TTransport
 from thrift.transport import TSocket
+from thrift.transport import TSSLSocket
 from thrift.transport import THttpClient
 from thrift.protocol import TBinaryProtocol
 
-import ThriftHiveMetastore
-from ttypes import *
+from hive_metastore import ThriftHiveMetastore
+from hive_metastore.ttypes import *
 
 if len(sys.argv) <= 1 or sys.argv[1] == '--help':
-  print ''
-  print 'Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] function [arg1 [arg2...]]'
-  print ''
-  print 'Functions:'
-  print '  string getMetaConf(string key)'
-  print '  void setMetaConf(string key, string value)'
-  print '  void create_database(Database database)'
-  print '  Database get_database(string name)'
-  print '  void drop_database(string name, bool deleteData, bool cascade)'
-  print '   get_databases(string pattern)'
-  print '   get_all_databases()'
-  print '  void alter_database(string dbname, Database db)'
-  print '  Type get_type(string name)'
-  print '  bool create_type(Type type)'
-  print '  bool drop_type(string type)'
-  print '   get_type_all(string name)'
-  print '   get_fields(string db_name, string table_name)'
-  print '   get_fields_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)'
-  print '   get_schema(string db_name, string table_name)'
-  print '   get_schema_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)'
-  print '  void create_table(Table tbl)'
-  print '  void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context)'
-  print '  void drop_table(string dbname, string name, bool deleteData)'
-  print '  void drop_table_with_environment_context(string dbname, string name, bool deleteData, EnvironmentContext environment_context)'
-  print '   get_tables(string db_name, string pattern)'
-  print '   get_all_tables(string db_name)'
-  print '  Table get_table(string dbname, string tbl_name)'
-  print '   get_table_objects_by_name(string dbname,  tbl_names)'
-  print '   get_table_names_by_filter(string dbname, string filter, i16 max_tables)'
-  print '  void alter_table(string dbname, string tbl_name, Table new_tbl)'
-  print '  void alter_table_with_environment_context(string dbname, string tbl_name, Table new_tbl, EnvironmentContext environment_context)'
-  print '  void alter_table_with_cascade(string dbname, string tbl_name, Table new_tbl, bool cascade)'
-  print '  Partition add_partition(Partition new_part)'
-  print '  Partition add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context)'
-  print '  i32 add_partitions( new_parts)'
-  print '  i32 add_partitions_pspec( new_parts)'
-  print '  Partition append_partition(string db_name, string tbl_name,  part_vals)'
-  print '  AddPartitionsResult add_partitions_req(AddPartitionsRequest request)'
-  print '  Partition append_partition_with_environment_context(string db_name, string tbl_name,  part_vals, EnvironmentContext environment_context)'
-  print '  Partition append_partition_by_name(string db_name, string tbl_name, string part_name)'
-  print '  Partition append_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, EnvironmentContext environment_context)'
-  print '  bool drop_partition(string db_name, string tbl_name,  part_vals, bool deleteData)'
-  print '  bool drop_partition_with_environment_context(string db_name, string tbl_name,  part_vals, bool deleteData, EnvironmentContext environment_context)'
-  print '  bool drop_partition_by_name(string db_name, string tbl_name, string part_name, bool deleteData)'
-  print '  bool drop_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, bool deleteData, EnvironmentContext environment_context)'
-  print '  DropPartitionsResult drop_partitions_req(DropPartitionsRequest req)'
-  print '  Partition get_partition(string db_name, string tbl_name,  part_vals)'
-  print '  Partition exchange_partition( partitionSpecs, string source_db, string source_table_name, string dest_db, string dest_table_name)'
-  print '  Partition get_partition_with_auth(string db_name, string tbl_name,  part_vals, string user_name,  group_names)'
-  print '  Partition get_partition_by_name(string db_name, string tbl_name, string part_name)'
-  print '   get_partitions(string db_name, string tbl_name, i16 max_parts)'
-  print '   get_partitions_with_auth(string db_name, string tbl_name, i16 max_parts, string user_name,  group_names)'
-  print '   get_partitions_pspec(string db_name, string tbl_name, i32 max_parts)'
-  print '   get_partition_names(string db_name, string tbl_name, i16 max_parts)'
-  print '   get_partitions_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)'
-  print '   get_partitions_ps_with_auth(string db_name, string tbl_name,  part_vals, i16 max_parts, string user_name,  group_names)'
-  print '   get_partition_names_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)'
-  print '   get_partitions_by_filter(string db_name, string tbl_name, string filter, i16 max_parts)'
-  print '   get_part_specs_by_filter(string db_name, string tbl_name, string filter, i32 max_parts)'
-  print '  PartitionsByExprResult get_partitions_by_expr(PartitionsByExprRequest req)'
-  print '   get_partitions_by_names(string db_name, string tbl_name,  names)'
-  print '  void alter_partition(string db_name, string tbl_name, Partition new_part)'
-  print '  void alter_partitions(string db_name, string tbl_name,  new_parts)'
-  print '  void alter_partition_with_environment_context(string db_name, string tbl_name, Partition new_part, EnvironmentContext environment_context)'
-  print '  void rename_partition(string db_name, string tbl_name,  part_vals, Partition new_part)'
-  print '  bool partition_name_has_valid_characters( part_vals, bool throw_exception)'
-  print '  string get_config_value(string name, string defaultValue)'
-  print '   partition_name_to_vals(string part_name)'
-  print '   partition_name_to_spec(string part_name)'
-  print '  void markPartitionForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)'
-  print '  bool isPartitionMarkedForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)'
-  print '  Index add_index(Index new_index, Table index_table)'
-  print '  void alter_index(string dbname, string base_tbl_name, string idx_name, Index new_idx)'
-  print '  bool drop_index_by_name(string db_name, string tbl_name, string index_name, bool deleteData)'
-  print '  Index get_index_by_name(string db_name, string tbl_name, string index_name)'
-  print '   get_indexes(string db_name, string tbl_name, i16 max_indexes)'
-  print '   get_index_names(string db_name, string tbl_name, i16 max_indexes)'
-  print '  bool update_table_column_statistics(ColumnStatistics stats_obj)'
-  print '  bool update_partition_column_statistics(ColumnStatistics stats_obj)'
-  print '  ColumnStatistics get_table_column_statistics(string db_name, string tbl_name, string col_name)'
-  print '  ColumnStatistics get_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)'
-  print '  TableStatsResult get_table_statistics_req(TableStatsRequest request)'
-  print '  PartitionsStatsResult get_partitions_statistics_req(PartitionsStatsRequest request)'
-  print '  AggrStats get_aggr_stats_for(PartitionsStatsRequest request)'
-  print '  bool set_aggr_stats_for(SetPartitionsStatsRequest request)'
-  print '  bool delete_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)'
-  print '  bool delete_table_column_statistics(string db_name, string tbl_name, string col_name)'
-  print '  void create_function(Function func)'
-  print '  void drop_function(string dbName, string funcName)'
-  print '  void alter_function(string dbName, string funcName, Function newFunc)'
-  print '   get_functions(string dbName, string pattern)'
-  print '  Function get_function(string dbName, string funcName)'
-  print '  bool create_role(Role role)'
-  print '  bool drop_role(string role_name)'
-  print '   get_role_names()'
-  print '  bool grant_role(string role_name, string principal_name, PrincipalType principal_type, string grantor, PrincipalType grantorType, bool grant_option)'
-  print '  bool revoke_role(string role_name, string principal_name, PrincipalType principal_type)'
-  print '   list_roles(string principal_name, PrincipalType principal_type)'
-  print '  GrantRevokeRoleResponse grant_revoke_role(GrantRevokeRoleRequest request)'
-  print '  GetPrincipalsInRoleResponse get_principals_in_role(GetPrincipalsInRoleRequest request)'
-  print '  GetRoleGrantsForPrincipalResponse get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request)'
-  print '  PrincipalPrivilegeSet get_privilege_set(HiveObjectRef hiveObject, string user_name,  group_names)'
-  print '   list_privileges(string principal_name, PrincipalType principal_type, HiveObjectRef hiveObject)'
-  print '  bool grant_privileges(PrivilegeBag privileges)'
-  print '  bool revoke_privileges(PrivilegeBag privileges)'
-  print '  GrantRevokePrivilegeResponse grant_revoke_privileges(GrantRevokePrivilegeRequest request)'
-  print '   set_ugi(string user_name,  group_names)'
-  print '  string get_delegation_token(string token_owner, string renewer_kerberos_principal_name)'
-  print '  i64 renew_delegation_token(string token_str_form)'
-  print '  void cancel_delegation_token(string token_str_form)'
-  print '  GetOpenTxnsResponse get_open_txns()'
-  print '  GetOpenTxnsInfoResponse get_open_txns_info()'
-  print '  OpenTxnsResponse open_txns(OpenTxnRequest rqst)'
-  print '  void abort_txn(AbortTxnRequest rqst)'
-  print '  void commit_txn(CommitTxnRequest rqst)'
-  print '  LockResponse lock(LockRequest rqst)'
-  print '  LockResponse check_lock(CheckLockRequest rqst)'
-  print '  void unlock(UnlockRequest rqst)'
-  print '  ShowLocksResponse show_locks(ShowLocksRequest rqst)'
-  print '  void heartbeat(HeartbeatRequest ids)'
-  print '  HeartbeatTxnRangeResponse heartbeat_txn_range(HeartbeatTxnRangeRequest txns)'
-  print '  void compact(CompactionRequest rqst)'
-  print '  ShowCompactResponse show_compact(ShowCompactRequest rqst)'
-  print '  void add_dynamic_partitions(AddDynamicPartitions rqst)'
-  print '  NotificationEventResponse get_next_notification(NotificationEventRequest rqst)'
-  print '  CurrentNotificationEventId get_current_notificationEventId()'
-  print '  FireEventResponse fire_listener_event(FireEventRequest rqst)'
-  print ''
+  print('')
+  print('Usage: ' + sys.argv[0] + ' [-h host[:port]] [-u url] [-f[ramed]] [-s[sl]] function [arg1 [arg2...]]')
+  print('')
+  print('Functions:')
+  print('  string getMetaConf(string key)')
+  print('  void setMetaConf(string key, string value)')
+  print('  void create_database(Database database)')
+  print('  Database get_database(string name)')
+  print('  void drop_database(string name, bool deleteData, bool cascade)')
+  print('   get_databases(string pattern)')
+  print('   get_all_databases()')
+  print('  void alter_database(string dbname, Database db)')
+  print('  Type get_type(string name)')
+  print('  bool create_type(Type type)')
+  print('  bool drop_type(string type)')
+  print('   get_type_all(string name)')
+  print('   get_fields(string db_name, string table_name)')
+  print('   get_fields_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)')
+  print('   get_schema(string db_name, string table_name)')
+  print('   get_schema_with_environment_context(string db_name, string table_name, EnvironmentContext environment_context)')
+  print('  void create_table(Table tbl)')
+  print('  void create_table_with_environment_context(Table tbl, EnvironmentContext environment_context)')
+  print('  void drop_table(string dbname, string name, bool deleteData)')
+  print('  void drop_table_with_environment_context(string dbname, string name, bool deleteData, EnvironmentContext environment_context)')
+  print('   get_tables(string db_name, string pattern)')
+  print('   get_all_tables(string db_name)')
+  print('  Table get_table(string dbname, string tbl_name)')
+  print('   get_table_objects_by_name(string dbname,  tbl_names)')
+  print('   get_table_names_by_filter(string dbname, string filter, i16 max_tables)')
+  print('  void alter_table(string dbname, string tbl_name, Table new_tbl)')
+  print('  void alter_table_with_environment_context(string dbname, string tbl_name, Table new_tbl, EnvironmentContext environment_context)')
+  print('  void alter_table_with_cascade(string dbname, string tbl_name, Table new_tbl, bool cascade)')
+  print('  Partition add_partition(Partition new_part)')
+  print('  Partition add_partition_with_environment_context(Partition new_part, EnvironmentContext environment_context)')
+  print('  i32 add_partitions( new_parts)')
+  print('  i32 add_partitions_pspec( new_parts)')
+  print('  Partition append_partition(string db_name, string tbl_name,  part_vals)')
+  print('  AddPartitionsResult add_partitions_req(AddPartitionsRequest request)')
+  print('  Partition append_partition_with_environment_context(string db_name, string tbl_name,  part_vals, EnvironmentContext environment_context)')
+  print('  Partition append_partition_by_name(string db_name, string tbl_name, string part_name)')
+  print('  Partition append_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, EnvironmentContext environment_context)')
+  print('  bool drop_partition(string db_name, string tbl_name,  part_vals, bool deleteData)')
+  print('  bool drop_partition_with_environment_context(string db_name, string tbl_name,  part_vals, bool deleteData, EnvironmentContext environment_context)')
+  print('  bool drop_partition_by_name(string db_name, string tbl_name, string part_name, bool deleteData)')
+  print('  bool drop_partition_by_name_with_environment_context(string db_name, string tbl_name, string part_name, bool deleteData, EnvironmentContext environment_context)')
+  print('  DropPartitionsResult drop_partitions_req(DropPartitionsRequest req)')
+  print('  Partition get_partition(string db_name, string tbl_name,  part_vals)')
+  print('  Partition exchange_partition( partitionSpecs, string source_db, string source_table_name, string dest_db, string dest_table_name)')
+  print('  Partition get_partition_with_auth(string db_name, string tbl_name,  part_vals, string user_name,  group_names)')
+  print('  Partition get_partition_by_name(string db_name, string tbl_name, string part_name)')
+  print('   get_partitions(string db_name, string tbl_name, i16 max_parts)')
+  print('   get_partitions_with_auth(string db_name, string tbl_name, i16 max_parts, string user_name,  group_names)')
+  print('   get_partitions_pspec(string db_name, string tbl_name, i32 max_parts)')
+  print('   get_partition_names(string db_name, string tbl_name, i16 max_parts)')
+  print('   get_partitions_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)')
+  print('   get_partitions_ps_with_auth(string db_name, string tbl_name,  part_vals, i16 max_parts, string user_name,  group_names)')
+  print('   get_partition_names_ps(string db_name, string tbl_name,  part_vals, i16 max_parts)')
+  print('   get_partitions_by_filter(string db_name, string tbl_name, string filter, i16 max_parts)')
+  print('   get_part_specs_by_filter(string db_name, string tbl_name, string filter, i32 max_parts)')
+  print('  PartitionsByExprResult get_partitions_by_expr(PartitionsByExprRequest req)')
+  print('   get_partitions_by_names(string db_name, string tbl_name,  names)')
+  print('  void alter_partition(string db_name, string tbl_name, Partition new_part)')
+  print('  void alter_partitions(string db_name, string tbl_name,  new_parts)')
+  print('  void alter_partition_with_environment_context(string db_name, string tbl_name, Partition new_part, EnvironmentContext environment_context)')
+  print('  void rename_partition(string db_name, string tbl_name,  part_vals, Partition new_part)')
+  print('  bool partition_name_has_valid_characters( part_vals, bool throw_exception)')
+  print('  string get_config_value(string name, string defaultValue)')
+  print('   partition_name_to_vals(string part_name)')
+  print('   partition_name_to_spec(string part_name)')
+  print('  void markPartitionForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)')
+  print('  bool isPartitionMarkedForEvent(string db_name, string tbl_name,  part_vals, PartitionEventType eventType)')
+  print('  Index add_index(Index new_index, Table index_table)')
+  print('  void alter_index(string dbname, string base_tbl_name, string idx_name, Index new_idx)')
+  print('  bool drop_index_by_name(string db_name, string tbl_name, string index_name, bool deleteData)')
+  print('  Index get_index_by_name(string db_name, string tbl_name, string index_name)')
+  print('   get_indexes(string db_name, string tbl_name, i16 max_indexes)')
+  print('   get_index_names(string db_name, string tbl_name, i16 max_indexes)')
+  print('  bool update_table_column_statistics(ColumnStatistics stats_obj)')
+  print('  bool update_partition_column_statistics(ColumnStatistics stats_obj)')
+  print('  ColumnStatistics get_table_column_statistics(string db_name, string tbl_name, string col_name)')
+  print('  ColumnStatistics get_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)')
+  print('  TableStatsResult get_table_statistics_req(TableStatsRequest request)')
+  print('  PartitionsStatsResult get_partitions_statistics_req(PartitionsStatsRequest request)')
+  print('  AggrStats get_aggr_stats_for(PartitionsStatsRequest request)')
+  print('  bool set_aggr_stats_for(SetPartitionsStatsRequest request)')
+  print('  bool delete_partition_column_statistics(string db_name, string tbl_name, string part_name, string col_name)')
+  print('  bool delete_table_column_statistics(string db_name, string tbl_name, string col_name)')
+  print('  void create_function(Function func)')
+  print('  void drop_function(string dbName, string funcName)')
+  print('  void alter_function(string dbName, string funcName, Function newFunc)')
+  print('   get_functions(string dbName, string pattern)')
+  print('  Function get_function(string dbName, string funcName)')
+  print('  bool create_role(Role role)')
+  print('  bool drop_role(string role_name)')
+  print('   get_role_names()')
+  print('  bool grant_role(string role_name, string principal_name, PrincipalType principal_type, string grantor, PrincipalType grantorType, bool grant_option)')
+  print('  bool revoke_role(string role_name, string principal_name, PrincipalType principal_type)')
+  print('   list_roles(string principal_name, PrincipalType principal_type)')
+  print('  GrantRevokeRoleResponse grant_revoke_role(GrantRevokeRoleRequest request)')
+  print('  GetPrincipalsInRoleResponse get_principals_in_role(GetPrincipalsInRoleRequest request)')
+  print('  GetRoleGrantsForPrincipalResponse get_role_grants_for_principal(GetRoleGrantsForPrincipalRequest request)')
+  print('  PrincipalPrivilegeSet get_privilege_set(HiveObjectRef hiveObject, string user_name,  group_names)')
+  print('   list_privileges(string principal_name, PrincipalType principal_type, HiveObjectRef hiveObject)')
+  print('  bool grant_privileges(PrivilegeBag privileges)')
+  print('  bool revoke_privileges(PrivilegeBag privileges)')
+  print('  GrantRevokePrivilegeResponse grant_revoke_privileges(GrantRevokePrivilegeRequest request)')
+  print('   set_ugi(string user_name,  group_names)')
+  print('  string get_delegation_token(string token_owner, string renewer_kerberos_principal_name)')
+  print('  i64 renew_delegation_token(string token_str_form)')
+  print('  void cancel_delegation_token(string token_str_form)')
+  print('  GetOpenTxnsResponse get_open_txns()')
+  print('  GetOpenTxnsInfoResponse get_open_txns_info()')
+  print('  OpenTxnsResponse open_txns(OpenTxnRequest rqst)')
+  print('  void abort_txn(AbortTxnRequest rqst)')
+  print('  void commit_txn(CommitTxnRequest rqst)')
+  print('  LockResponse lock(LockRequest rqst)')
+  print('  LockResponse check_lock(CheckLockRequest rqst)')
+  print('  void unlock(UnlockRequest rqst)')
+  print('  ShowLocksResponse show_locks(ShowLocksRequest rqst)')
+  print('  void heartbeat(HeartbeatRequest ids)')
+  print('  HeartbeatTxnRangeResponse heartbeat_txn_range(HeartbeatTxnRangeRequest txns)')
+  print('  void compact(CompactionRequest rqst)')
+  print('  ShowCompactResponse show_compact(ShowCompactRequest rqst)')
+  print('  void add_dynamic_partitions(AddDynamicPartitions rqst)')
+  print('  NotificationEventResponse get_next_notification(NotificationEventRequest rqst)')
+  print('  CurrentNotificationEventId get_current_notificationEventId()')
+  print('  FireEventResponse fire_listener_event(FireEventRequest rqst)')
+  print('  string getName()')
+  print('  string getVersion()')
+  print('  fb_status getStatus()')
+  print('  string getStatusDetails()')
+  print('   getCounters()')
+  print('  i64 getCounter(string key)')
+  print('  void setOption(string key, string value)')
+  print('  string getOption(string key)')
+  print('   getOptions()')
+  print('  string getCpuProfile(i32 profileDurationInSec)')
+  print('  i64 aliveSince()')
+  print('  void reinitialize()')
+  print('  void shutdown()')
+  print('')
   sys.exit(0)
 
 pp = pprint.PrettyPrinter(indent = 2)
@@ -154,6 +168,7 @@ host = 'localhost'
 port = 9090
 uri = ''
 framed = False
+ssl = False
 http = False
 argi = 1
 
@@ -182,13 +197,17 @@ if sys.argv[argi] == '-f' or sys.argv[argi] == '-framed':
   framed = True
   argi += 1
 
+if sys.argv[argi] == '-s' or sys.argv[argi] == '-ssl':
+  ssl = True
+  argi += 1
+
 cmd = sys.argv[argi]
 args = sys.argv[argi+1:]
 
 if http:
   transport = THttpClient.THttpClient(host, port, uri)
 else:
-  socket = TSocket.TSocket(host, port)
+  socket = TSSLSocket.TSSLSocket(host, port, validate=False) if ssl else TSocket.TSocket(host, port)
   if framed:
     transport = TTransport.TFramedTransport(socket)
   else:
@@ -199,744 +218,822 @@ transport.open()
 
 if cmd == 'getMetaConf':
   if len(args) != 1:
-    print 'getMetaConf requires 1 args'
+    print('getMetaConf requires 1 args')
     sys.exit(1)
   pp.pprint(client.getMetaConf(args[0],))
 
 elif cmd == 'setMetaConf':
   if len(args) != 2:
-    print 'setMetaConf requires 2 args'
+    print('setMetaConf requires 2 args')
     sys.exit(1)
   pp.pprint(client.setMetaConf(args[0],args[1],))
 
 elif cmd == 'create_database':
   if len(args) != 1:
-    print 'create_database requires 1 args'
+    print('create_database requires 1 args')
     sys.exit(1)
   pp.pprint(client.create_database(eval(args[0]),))
 
 elif cmd == 'get_database':
   if len(args) != 1:
-    print 'get_database requires 1 args'
+    print('get_database requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_database(args[0],))
 
 elif cmd == 'drop_database':
   if len(args) != 3:
-    print 'drop_database requires 3 args'
+    print('drop_database requires 3 args')
     sys.exit(1)
   pp.pprint(client.drop_database(args[0],eval(args[1]),eval(args[2]),))
 
 elif cmd == 'get_databases':
   if len(args) != 1:
-    print 'get_databases requires 1 args'
+    print('get_databases requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_databases(args[0],))
 
 elif cmd == 'get_all_databases':
   if len(args) != 0:
-    print 'get_all_databases requires 0 args'
+    print('get_all_databases requires 0 args')
     sys.exit(1)
   pp.pprint(client.get_all_databases())
 
 elif cmd == 'alter_database':
   if len(args) != 2:
-    print 'alter_database requires 2 args'
+    print('alter_database requires 2 args')
     sys.exit(1)
   pp.pprint(client.alter_database(args[0],eval(args[1]),))
 
 elif cmd == 'get_type':
   if len(args) != 1:
-    print 'get_type requires 1 args'
+    print('get_type requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_type(args[0],))
 
 elif cmd == 'create_type':
   if len(args) != 1:
-    print 'create_type requires 1 args'
+    print('create_type requires 1 args')
     sys.exit(1)
   pp.pprint(client.create_type(eval(args[0]),))
 
 elif cmd == 'drop_type':
   if len(args) != 1:
-    print 'drop_type requires 1 args'
+    print('drop_type requires 1 args')
     sys.exit(1)
   pp.pprint(client.drop_type(args[0],))
 
 elif cmd == 'get_type_all':
   if len(args) != 1:
-    print 'get_type_all requires 1 args'
+    print('get_type_all requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_type_all(args[0],))
 
 elif cmd == 'get_fields':
   if len(args) != 2:
-    print 'get_fields requires 2 args'
+    print('get_fields requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_fields(args[0],args[1],))
 
 elif cmd == 'get_fields_with_environment_context':
   if len(args) != 3:
-    print 'get_fields_with_environment_context requires 3 args'
+    print('get_fields_with_environment_context requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_fields_with_environment_context(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_schema':
   if len(args) != 2:
-    print 'get_schema requires 2 args'
+    print('get_schema requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_schema(args[0],args[1],))
 
 elif cmd == 'get_schema_with_environment_context':
   if len(args) != 3:
-    print 'get_schema_with_environment_context requires 3 args'
+    print('get_schema_with_environment_context requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_schema_with_environment_context(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'create_table':
   if len(args) != 1:
-    print 'create_table requires 1 args'
+    print('create_table requires 1 args')
     sys.exit(1)
   pp.pprint(client.create_table(eval(args[0]),))
 
 elif cmd == 'create_table_with_environment_context':
   if len(args) != 2:
-    print 'create_table_with_environment_context requires 2 args'
+    print('create_table_with_environment_context requires 2 args')
     sys.exit(1)
   pp.pprint(client.create_table_with_environment_context(eval(args[0]),eval(args[1]),))
 
 elif cmd == 'drop_table':
   if len(args) != 3:
-    print 'drop_table requires 3 args'
+    print('drop_table requires 3 args')
     sys.exit(1)
   pp.pprint(client.drop_table(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'drop_table_with_environment_context':
   if len(args) != 4:
-    print 'drop_table_with_environment_context requires 4 args'
+    print('drop_table_with_environment_context requires 4 args')
     sys.exit(1)
   pp.pprint(client.drop_table_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'get_tables':
   if len(args) != 2:
-    print 'get_tables requires 2 args'
+    print('get_tables requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_tables(args[0],args[1],))
 
 elif cmd == 'get_all_tables':
   if len(args) != 1:
-    print 'get_all_tables requires 1 args'
+    print('get_all_tables requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_all_tables(args[0],))
 
 elif cmd == 'get_table':
   if len(args) != 2:
-    print 'get_table requires 2 args'
+    print('get_table requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_table(args[0],args[1],))
 
 elif cmd == 'get_table_objects_by_name':
   if len(args) != 2:
-    print 'get_table_objects_by_name requires 2 args'
+    print('get_table_objects_by_name requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_table_objects_by_name(args[0],eval(args[1]),))
 
 elif cmd == 'get_table_names_by_filter':
   if len(args) != 3:
-    print 'get_table_names_by_filter requires 3 args'
+    print('get_table_names_by_filter requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_table_names_by_filter(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'alter_table':
   if len(args) != 3:
-    print 'alter_table requires 3 args'
+    print('alter_table requires 3 args')
     sys.exit(1)
   pp.pprint(client.alter_table(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'alter_table_with_environment_context':
   if len(args) != 4:
-    print 'alter_table_with_environment_context requires 4 args'
+    print('alter_table_with_environment_context requires 4 args')
     sys.exit(1)
   pp.pprint(client.alter_table_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'alter_table_with_cascade':
   if len(args) != 4:
-    print 'alter_table_with_cascade requires 4 args'
+    print('alter_table_with_cascade requires 4 args')
     sys.exit(1)
   pp.pprint(client.alter_table_with_cascade(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'add_partition':
   if len(args) != 1:
-    print 'add_partition requires 1 args'
+    print('add_partition requires 1 args')
     sys.exit(1)
   pp.pprint(client.add_partition(eval(args[0]),))
 
 elif cmd == 'add_partition_with_environment_context':
   if len(args) != 2:
-    print 'add_partition_with_environment_context requires 2 args'
+    print('add_partition_with_environment_context requires 2 args')
     sys.exit(1)
   pp.pprint(client.add_partition_with_environment_context(eval(args[0]),eval(args[1]),))
 
 elif cmd == 'add_partitions':
   if len(args) != 1:
-    print 'add_partitions requires 1 args'
+    print('add_partitions requires 1 args')
     sys.exit(1)
   pp.pprint(client.add_partitions(eval(args[0]),))
 
 elif cmd == 'add_partitions_pspec':
   if len(args) != 1:
-    print 'add_partitions_pspec requires 1 args'
+    print('add_partitions_pspec requires 1 args')
     sys.exit(1)
   pp.pprint(client.add_partitions_pspec(eval(args[0]),))
 
 elif cmd == 'append_partition':
   if len(args) != 3:
-    print 'append_partition requires 3 args'
+    print('append_partition requires 3 args')
     sys.exit(1)
   pp.pprint(client.append_partition(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'add_partitions_req':
   if len(args) != 1:
-    print 'add_partitions_req requires 1 args'
+    print('add_partitions_req requires 1 args')
     sys.exit(1)
   pp.pprint(client.add_partitions_req(eval(args[0]),))
 
 elif cmd == 'append_partition_with_environment_context':
   if len(args) != 4:
-    print 'append_partition_with_environment_context requires 4 args'
+    print('append_partition_with_environment_context requires 4 args')
     sys.exit(1)
   pp.pprint(client.append_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'append_partition_by_name':
   if len(args) != 3:
-    print 'append_partition_by_name requires 3 args'
+    print('append_partition_by_name requires 3 args')
     sys.exit(1)
   pp.pprint(client.append_partition_by_name(args[0],args[1],args[2],))
 
 elif cmd == 'append_partition_by_name_with_environment_context':
   if len(args) != 4:
-    print 'append_partition_by_name_with_environment_context requires 4 args'
+    print('append_partition_by_name_with_environment_context requires 4 args')
     sys.exit(1)
   pp.pprint(client.append_partition_by_name_with_environment_context(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'drop_partition':
   if len(args) != 4:
-    print 'drop_partition requires 4 args'
+    print('drop_partition requires 4 args')
     sys.exit(1)
   pp.pprint(client.drop_partition(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'drop_partition_with_environment_context':
   if len(args) != 5:
-    print 'drop_partition_with_environment_context requires 5 args'
+    print('drop_partition_with_environment_context requires 5 args')
     sys.exit(1)
   pp.pprint(client.drop_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),eval(args[4]),))
 
 elif cmd == 'drop_partition_by_name':
   if len(args) != 4:
-    print 'drop_partition_by_name requires 4 args'
+    print('drop_partition_by_name requires 4 args')
     sys.exit(1)
   pp.pprint(client.drop_partition_by_name(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'drop_partition_by_name_with_environment_context':
   if len(args) != 5:
-    print 'drop_partition_by_name_with_environment_context requires 5 args'
+    print('drop_partition_by_name_with_environment_context requires 5 args')
     sys.exit(1)
   pp.pprint(client.drop_partition_by_name_with_environment_context(args[0],args[1],args[2],eval(args[3]),eval(args[4]),))
 
 elif cmd == 'drop_partitions_req':
   if len(args) != 1:
-    print 'drop_partitions_req requires 1 args'
+    print('drop_partitions_req requires 1 args')
     sys.exit(1)
   pp.pprint(client.drop_partitions_req(eval(args[0]),))
 
 elif cmd == 'get_partition':
   if len(args) != 3:
-    print 'get_partition requires 3 args'
+    print('get_partition requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partition(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'exchange_partition':
   if len(args) != 5:
-    print 'exchange_partition requires 5 args'
+    print('exchange_partition requires 5 args')
     sys.exit(1)
   pp.pprint(client.exchange_partition(eval(args[0]),args[1],args[2],args[3],args[4],))
 
 elif cmd == 'get_partition_with_auth':
   if len(args) != 5:
-    print 'get_partition_with_auth requires 5 args'
+    print('get_partition_with_auth requires 5 args')
     sys.exit(1)
   pp.pprint(client.get_partition_with_auth(args[0],args[1],eval(args[2]),args[3],eval(args[4]),))
 
 elif cmd == 'get_partition_by_name':
   if len(args) != 3:
-    print 'get_partition_by_name requires 3 args'
+    print('get_partition_by_name requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partition_by_name(args[0],args[1],args[2],))
 
 elif cmd == 'get_partitions':
   if len(args) != 3:
-    print 'get_partitions requires 3 args'
+    print('get_partitions requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partitions(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_partitions_with_auth':
   if len(args) != 5:
-    print 'get_partitions_with_auth requires 5 args'
+    print('get_partitions_with_auth requires 5 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_with_auth(args[0],args[1],eval(args[2]),args[3],eval(args[4]),))
 
 elif cmd == 'get_partitions_pspec':
   if len(args) != 3:
-    print 'get_partitions_pspec requires 3 args'
+    print('get_partitions_pspec requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_pspec(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_partition_names':
   if len(args) != 3:
-    print 'get_partition_names requires 3 args'
+    print('get_partition_names requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partition_names(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_partitions_ps':
   if len(args) != 4:
-    print 'get_partitions_ps requires 4 args'
+    print('get_partitions_ps requires 4 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_ps(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'get_partitions_ps_with_auth':
   if len(args) != 6:
-    print 'get_partitions_ps_with_auth requires 6 args'
+    print('get_partitions_ps_with_auth requires 6 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_ps_with_auth(args[0],args[1],eval(args[2]),eval(args[3]),args[4],eval(args[5]),))
 
 elif cmd == 'get_partition_names_ps':
   if len(args) != 4:
-    print 'get_partition_names_ps requires 4 args'
+    print('get_partition_names_ps requires 4 args')
     sys.exit(1)
   pp.pprint(client.get_partition_names_ps(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'get_partitions_by_filter':
   if len(args) != 4:
-    print 'get_partitions_by_filter requires 4 args'
+    print('get_partitions_by_filter requires 4 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_by_filter(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'get_part_specs_by_filter':
   if len(args) != 4:
-    print 'get_part_specs_by_filter requires 4 args'
+    print('get_part_specs_by_filter requires 4 args')
     sys.exit(1)
   pp.pprint(client.get_part_specs_by_filter(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'get_partitions_by_expr':
   if len(args) != 1:
-    print 'get_partitions_by_expr requires 1 args'
+    print('get_partitions_by_expr requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_by_expr(eval(args[0]),))
 
 elif cmd == 'get_partitions_by_names':
   if len(args) != 3:
-    print 'get_partitions_by_names requires 3 args'
+    print('get_partitions_by_names requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_by_names(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'alter_partition':
   if len(args) != 3:
-    print 'alter_partition requires 3 args'
+    print('alter_partition requires 3 args')
     sys.exit(1)
   pp.pprint(client.alter_partition(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'alter_partitions':
   if len(args) != 3:
-    print 'alter_partitions requires 3 args'
+    print('alter_partitions requires 3 args')
     sys.exit(1)
   pp.pprint(client.alter_partitions(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'alter_partition_with_environment_context':
   if len(args) != 4:
-    print 'alter_partition_with_environment_context requires 4 args'
+    print('alter_partition_with_environment_context requires 4 args')
     sys.exit(1)
   pp.pprint(client.alter_partition_with_environment_context(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'rename_partition':
   if len(args) != 4:
-    print 'rename_partition requires 4 args'
+    print('rename_partition requires 4 args')
     sys.exit(1)
   pp.pprint(client.rename_partition(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'partition_name_has_valid_characters':
   if len(args) != 2:
-    print 'partition_name_has_valid_characters requires 2 args'
+    print('partition_name_has_valid_characters requires 2 args')
     sys.exit(1)
   pp.pprint(client.partition_name_has_valid_characters(eval(args[0]),eval(args[1]),))
 
 elif cmd == 'get_config_value':
   if len(args) != 2:
-    print 'get_config_value requires 2 args'
+    print('get_config_value requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_config_value(args[0],args[1],))
 
 elif cmd == 'partition_name_to_vals':
   if len(args) != 1:
-    print 'partition_name_to_vals requires 1 args'
+    print('partition_name_to_vals requires 1 args')
     sys.exit(1)
   pp.pprint(client.partition_name_to_vals(args[0],))
 
 elif cmd == 'partition_name_to_spec':
   if len(args) != 1:
-    print 'partition_name_to_spec requires 1 args'
+    print('partition_name_to_spec requires 1 args')
     sys.exit(1)
   pp.pprint(client.partition_name_to_spec(args[0],))
 
 elif cmd == 'markPartitionForEvent':
   if len(args) != 4:
-    print 'markPartitionForEvent requires 4 args'
+    print('markPartitionForEvent requires 4 args')
     sys.exit(1)
   pp.pprint(client.markPartitionForEvent(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'isPartitionMarkedForEvent':
   if len(args) != 4:
-    print 'isPartitionMarkedForEvent requires 4 args'
+    print('isPartitionMarkedForEvent requires 4 args')
     sys.exit(1)
   pp.pprint(client.isPartitionMarkedForEvent(args[0],args[1],eval(args[2]),eval(args[3]),))
 
 elif cmd == 'add_index':
   if len(args) != 2:
-    print 'add_index requires 2 args'
+    print('add_index requires 2 args')
     sys.exit(1)
   pp.pprint(client.add_index(eval(args[0]),eval(args[1]),))
 
 elif cmd == 'alter_index':
   if len(args) != 4:
-    print 'alter_index requires 4 args'
+    print('alter_index requires 4 args')
     sys.exit(1)
   pp.pprint(client.alter_index(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'drop_index_by_name':
   if len(args) != 4:
-    print 'drop_index_by_name requires 4 args'
+    print('drop_index_by_name requires 4 args')
     sys.exit(1)
   pp.pprint(client.drop_index_by_name(args[0],args[1],args[2],eval(args[3]),))
 
 elif cmd == 'get_index_by_name':
   if len(args) != 3:
-    print 'get_index_by_name requires 3 args'
+    print('get_index_by_name requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_index_by_name(args[0],args[1],args[2],))
 
 elif cmd == 'get_indexes':
   if len(args) != 3:
-    print 'get_indexes requires 3 args'
+    print('get_indexes requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_indexes(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_index_names':
   if len(args) != 3:
-    print 'get_index_names requires 3 args'
+    print('get_index_names requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_index_names(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'update_table_column_statistics':
   if len(args) != 1:
-    print 'update_table_column_statistics requires 1 args'
+    print('update_table_column_statistics requires 1 args')
     sys.exit(1)
   pp.pprint(client.update_table_column_statistics(eval(args[0]),))
 
 elif cmd == 'update_partition_column_statistics':
   if len(args) != 1:
-    print 'update_partition_column_statistics requires 1 args'
+    print('update_partition_column_statistics requires 1 args')
     sys.exit(1)
   pp.pprint(client.update_partition_column_statistics(eval(args[0]),))
 
 elif cmd == 'get_table_column_statistics':
   if len(args) != 3:
-    print 'get_table_column_statistics requires 3 args'
+    print('get_table_column_statistics requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_table_column_statistics(args[0],args[1],args[2],))
 
 elif cmd == 'get_partition_column_statistics':
   if len(args) != 4:
-    print 'get_partition_column_statistics requires 4 args'
+    print('get_partition_column_statistics requires 4 args')
     sys.exit(1)
   pp.pprint(client.get_partition_column_statistics(args[0],args[1],args[2],args[3],))
 
 elif cmd == 'get_table_statistics_req':
   if len(args) != 1:
-    print 'get_table_statistics_req requires 1 args'
+    print('get_table_statistics_req requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_table_statistics_req(eval(args[0]),))
 
 elif cmd == 'get_partitions_statistics_req':
   if len(args) != 1:
-    print 'get_partitions_statistics_req requires 1 args'
+    print('get_partitions_statistics_req requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_partitions_statistics_req(eval(args[0]),))
 
 elif cmd == 'get_aggr_stats_for':
   if len(args) != 1:
-    print 'get_aggr_stats_for requires 1 args'
+    print('get_aggr_stats_for requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_aggr_stats_for(eval(args[0]),))
 
 elif cmd == 'set_aggr_stats_for':
   if len(args) != 1:
-    print 'set_aggr_stats_for requires 1 args'
+    print('set_aggr_stats_for requires 1 args')
     sys.exit(1)
   pp.pprint(client.set_aggr_stats_for(eval(args[0]),))
 
 elif cmd == 'delete_partition_column_statistics':
   if len(args) != 4:
-    print 'delete_partition_column_statistics requires 4 args'
+    print('delete_partition_column_statistics requires 4 args')
     sys.exit(1)
   pp.pprint(client.delete_partition_column_statistics(args[0],args[1],args[2],args[3],))
 
 elif cmd == 'delete_table_column_statistics':
   if len(args) != 3:
-    print 'delete_table_column_statistics requires 3 args'
+    print('delete_table_column_statistics requires 3 args')
     sys.exit(1)
   pp.pprint(client.delete_table_column_statistics(args[0],args[1],args[2],))
 
 elif cmd == 'create_function':
   if len(args) != 1:
-    print 'create_function requires 1 args'
+    print('create_function requires 1 args')
     sys.exit(1)
   pp.pprint(client.create_function(eval(args[0]),))
 
 elif cmd == 'drop_function':
   if len(args) != 2:
-    print 'drop_function requires 2 args'
+    print('drop_function requires 2 args')
     sys.exit(1)
   pp.pprint(client.drop_function(args[0],args[1],))
 
 elif cmd == 'alter_function':
   if len(args) != 3:
-    print 'alter_function requires 3 args'
+    print('alter_function requires 3 args')
     sys.exit(1)
   pp.pprint(client.alter_function(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'get_functions':
   if len(args) != 2:
-    print 'get_functions requires 2 args'
+    print('get_functions requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_functions(args[0],args[1],))
 
 elif cmd == 'get_function':
   if len(args) != 2:
-    print 'get_function requires 2 args'
+    print('get_function requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_function(args[0],args[1],))
 
 elif cmd == 'create_role':
   if len(args) != 1:
-    print 'create_role requires 1 args'
+    print('create_role requires 1 args')
     sys.exit(1)
   pp.pprint(client.create_role(eval(args[0]),))
 
 elif cmd == 'drop_role':
   if len(args) != 1:
-    print 'drop_role requires 1 args'
+    print('drop_role requires 1 args')
     sys.exit(1)
   pp.pprint(client.drop_role(args[0],))
 
 elif cmd == 'get_role_names':
   if len(args) != 0:
-    print 'get_role_names requires 0 args'
+    print('get_role_names requires 0 args')
     sys.exit(1)
   pp.pprint(client.get_role_names())
 
 elif cmd == 'grant_role':
   if len(args) != 6:
-    print 'grant_role requires 6 args'
+    print('grant_role requires 6 args')
     sys.exit(1)
   pp.pprint(client.grant_role(args[0],args[1],eval(args[2]),args[3],eval(args[4]),eval(args[5]),))
 
 elif cmd == 'revoke_role':
   if len(args) != 3:
-    print 'revoke_role requires 3 args'
+    print('revoke_role requires 3 args')
     sys.exit(1)
   pp.pprint(client.revoke_role(args[0],args[1],eval(args[2]),))
 
 elif cmd == 'list_roles':
   if len(args) != 2:
-    print 'list_roles requires 2 args'
+    print('list_roles requires 2 args')
     sys.exit(1)
   pp.pprint(client.list_roles(args[0],eval(args[1]),))
 
 elif cmd == 'grant_revoke_role':
   if len(args) != 1:
-    print 'grant_revoke_role requires 1 args'
+    print('grant_revoke_role requires 1 args')
     sys.exit(1)
   pp.pprint(client.grant_revoke_role(eval(args[0]),))
 
 elif cmd == 'get_principals_in_role':
   if len(args) != 1:
-    print 'get_principals_in_role requires 1 args'
+    print('get_principals_in_role requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_principals_in_role(eval(args[0]),))
 
 elif cmd == 'get_role_grants_for_principal':
   if len(args) != 1:
-    print 'get_role_grants_for_principal requires 1 args'
+    print('get_role_grants_for_principal requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_role_grants_for_principal(eval(args[0]),))
 
 elif cmd == 'get_privilege_set':
   if len(args) != 3:
-    print 'get_privilege_set requires 3 args'
+    print('get_privilege_set requires 3 args')
     sys.exit(1)
   pp.pprint(client.get_privilege_set(eval(args[0]),args[1],eval(args[2]),))
 
 elif cmd == 'list_privileges':
   if len(args) != 3:
-    print 'list_privileges requires 3 args'
+    print('list_privileges requires 3 args')
     sys.exit(1)
   pp.pprint(client.list_privileges(args[0],eval(args[1]),eval(args[2]),))
 
 elif cmd == 'grant_privileges':
   if len(args) != 1:
-    print 'grant_privileges requires 1 args'
+    print('grant_privileges requires 1 args')
     sys.exit(1)
   pp.pprint(client.grant_privileges(eval(args[0]),))
 
 elif cmd == 'revoke_privileges':
   if len(args) != 1:
-    print 'revoke_privileges requires 1 args'
+    print('revoke_privileges requires 1 args')
     sys.exit(1)
   pp.pprint(client.revoke_privileges(eval(args[0]),))
 
 elif cmd == 'grant_revoke_privileges':
   if len(args) != 1:
-    print 'grant_revoke_privileges requires 1 args'
+    print('grant_revoke_privileges requires 1 args')
     sys.exit(1)
   pp.pprint(client.grant_revoke_privileges(eval(args[0]),))
 
 elif cmd == 'set_ugi':
   if len(args) != 2:
-    print 'set_ugi requires 2 args'
+    print('set_ugi requires 2 args')
     sys.exit(1)
   pp.pprint(client.set_ugi(args[0],eval(args[1]),))
 
 elif cmd == 'get_delegation_token':
   if len(args) != 2:
-    print 'get_delegation_token requires 2 args'
+    print('get_delegation_token requires 2 args')
     sys.exit(1)
   pp.pprint(client.get_delegation_token(args[0],args[1],))
 
 elif cmd == 'renew_delegation_token':
   if len(args) != 1:
-    print 'renew_delegation_token requires 1 args'
+    print('renew_delegation_token requires 1 args')
     sys.exit(1)
   pp.pprint(client.renew_delegation_token(args[0],))
 
 elif cmd == 'cancel_delegation_token':
   if len(args) != 1:
-    print 'cancel_delegation_token requires 1 args'
+    print('cancel_delegation_token requires 1 args')
     sys.exit(1)
   pp.pprint(client.cancel_delegation_token(args[0],))
 
 elif cmd == 'get_open_txns':
   if len(args) != 0:
-    print 'get_open_txns requires 0 args'
+    print('get_open_txns requires 0 args')
     sys.exit(1)
   pp.pprint(client.get_open_txns())
 
 elif cmd == 'get_open_txns_info':
   if len(args) != 0:
-    print 'get_open_txns_info requires 0 args'
+    print('get_open_txns_info requires 0 args')
     sys.exit(1)
   pp.pprint(client.get_open_txns_info())
 
 elif cmd == 'open_txns':
   if len(args) != 1:
-    print 'open_txns requires 1 args'
+    print('open_txns requires 1 args')
     sys.exit(1)
   pp.pprint(client.open_txns(eval(args[0]),))
 
 elif cmd == 'abort_txn':
   if len(args) != 1:
-    print 'abort_txn requires 1 args'
+    print('abort_txn requires 1 args')
     sys.exit(1)
   pp.pprint(client.abort_txn(eval(args[0]),))
 
 elif cmd == 'commit_txn':
   if len(args) != 1:
-    print 'commit_txn requires 1 args'
+    print('commit_txn requires 1 args')
     sys.exit(1)
   pp.pprint(client.commit_txn(eval(args[0]),))
 
 elif cmd == 'lock':
   if len(args) != 1:
-    print 'lock requires 1 args'
+    print('lock requires 1 args')
     sys.exit(1)
   pp.pprint(client.lock(eval(args[0]),))
 
 elif cmd == 'check_lock':
   if len(args) != 1:
-    print 'check_lock requires 1 args'
+    print('check_lock requires 1 args')
     sys.exit(1)
   pp.pprint(client.check_lock(eval(args[0]),))
 
 elif cmd == 'unlock':
   if len(args) != 1:
-    print 'unlock requires 1 args'
+    print('unlock requires 1 args')
     sys.exit(1)
   pp.pprint(client.unlock(eval(args[0]),))
 
 elif cmd == 'show_locks':
   if len(args) != 1:
-    print 'show_locks requires 1 args'
+    print('show_locks requires 1 args')
     sys.exit(1)
   pp.pprint(client.show_locks(eval(args[0]),))
 
 elif cmd == 'heartbeat':
   if len(args) != 1:
-    print 'heartbeat requires 1 args'
+    print('heartbeat requires 1 args')
     sys.exit(1)
   pp.pprint(client.heartbeat(eval(args[0]),))
 
 elif cmd == 'heartbeat_txn_range':
   if len(args) != 1:
-    print 'heartbeat_txn_range requires 1 args'
+    print('heartbeat_txn_range requires 1 args')
     sys.exit(1)
   pp.pprint(client.heartbeat_txn_range(eval(args[0]),))
 
 elif cmd == 'compact':
   if len(args) != 1:
-    print 'compact requires 1 args'
+    print('compact requires 1 args')
     sys.exit(1)
   pp.pprint(client.compact(eval(args[0]),))
 
 elif cmd == 'show_compact':
   if len(args) != 1:
-    print 'show_compact requires 1 args'
+    print('show_compact requires 1 args')
     sys.exit(1)
   pp.pprint(client.show_compact(eval(args[0]),))
 
 elif cmd == 'add_dynamic_partitions':
   if len(args) != 1:
-    print 'add_dynamic_partitions requires 1 args'
+    print('add_dynamic_partitions requires 1 args')
     sys.exit(1)
   pp.pprint(client.add_dynamic_partitions(eval(args[0]),))
 
 elif cmd == 'get_next_notification':
   if len(args) != 1:
-    print 'get_next_notification requires 1 args'
+    print('get_next_notification requires 1 args')
     sys.exit(1)
   pp.pprint(client.get_next_notification(eval(args[0]),))
 
 elif cmd == 'get_current_notificationEventId':
   if len(args) != 0:
-    print 'get_current_notificationEventId requires 0 args'
+    print('get_current_notificationEventId requires 0 args')
     sys.exit(1)
   pp.pprint(client.get_current_notificationEventId())
 
 elif cmd == 'fire_listener_event':
   if len(args) != 1:
-    print 'fire_listener_event requires 1 args'
+    print('fire_listener_event requires 1 args')
     sys.exit(1)
   pp.pprint(client.fire_listener_event(eval(args[0]),))
 
+elif cmd == 'getName':
+  if len(args) != 0:
+    print('getName requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getName())
+
+elif cmd == 'getVersion':
+  if len(args) != 0:
+    print('getVersion requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getVersion())
+
+elif cmd == 'getStatus':
+  if len(args) != 0:
+    print('getStatus requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getStatus())
+
+elif cmd == 'getStatusDetails':
+  if len(args) != 0:
+    print('getStatusDetails requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getStatusDetails())
+
+elif cmd == 'getCounters':
+  if len(args) != 0:
+    print('getCounters requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getCounters())
+
+elif cmd == 'getCounter':
+  if len(args) != 1:
+    print('getCounter requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getCounter(args[0],))
+
+elif cmd == 'setOption':
+  if len(args) != 2:
+    print('setOption requires 2 args')
+    sys.exit(1)
+  pp.pprint(client.setOption(args[0],args[1],))
+
+elif cmd == 'getOption':
+  if len(args) != 1:
+    print('getOption requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getOption(args[0],))
+
+elif cmd == 'getOptions':
+  if len(args) != 0:
+    print('getOptions requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.getOptions())
+
+elif cmd == 'getCpuProfile':
+  if len(args) != 1:
+    print('getCpuProfile requires 1 args')
+    sys.exit(1)
+  pp.pprint(client.getCpuProfile(eval(args[0]),))
+
+elif cmd == 'aliveSince':
+  if len(args) != 0:
+    print('aliveSince requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.aliveSince())
+
+elif cmd == 'reinitialize':
+  if len(args) != 0:
+    print('reinitialize requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.reinitialize())
+
+elif cmd == 'shutdown':
+  if len(args) != 0:
+    print('shutdown requires 0 args')
+    sys.exit(1)
+  pp.pprint(client.shutdown())
+
 else:
-  print 'Unrecognized method %s' % cmd
+  print('Unrecognized method %s' % cmd)
   sys.exit(1)
 
 transport.close()


[27/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-py/hive_metastore/constants.py
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/constants.py b/metastore/src/gen/thrift/gen-py/hive_metastore/constants.py
index 81f70eb..f86fda9 100644
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/constants.py
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/constants.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py b/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
index 6afa506..64cd4a0 100644
--- a/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
+++ b/metastore/src/gen/thrift/gen-py/hive_metastore/ttypes.py
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #
@@ -275,6 +275,12 @@ class Version:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.version)
+    value = (value * 31) ^ hash(self.comments)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -359,6 +365,13 @@ class FieldSchema:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.name)
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.comment)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -464,6 +477,14 @@ class Type:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.name)
+    value = (value * 31) ^ hash(self.type1)
+    value = (value * 31) ^ hash(self.type2)
+    value = (value * 31) ^ hash(self.fields)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -580,6 +601,15 @@ class HiveObjectRef:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.objectType)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.objectName)
+    value = (value * 31) ^ hash(self.partValues)
+    value = (value * 31) ^ hash(self.columnName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -688,6 +718,15 @@ class PrivilegeGrantInfo:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.privilege)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.grantor)
+    value = (value * 31) ^ hash(self.grantorType)
+    value = (value * 31) ^ hash(self.grantOption)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -786,6 +825,14 @@ class HiveObjectPrivilege:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.hiveObject)
+    value = (value * 31) ^ hash(self.principalName)
+    value = (value * 31) ^ hash(self.principalType)
+    value = (value * 31) ^ hash(self.grantInfo)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -855,6 +902,11 @@ class PrivilegeBag:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.privileges)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -898,7 +950,7 @@ class PrincipalPrivilegeSet:
       if fid == 1:
         if ftype == TType.MAP:
           self.userPrivileges = {}
-          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin() 
+          (_ktype22, _vtype23, _size21 ) = iprot.readMapBegin()
           for _i25 in xrange(_size21):
             _key26 = iprot.readString();
             _val27 = []
@@ -915,7 +967,7 @@ class PrincipalPrivilegeSet:
       elif fid == 2:
         if ftype == TType.MAP:
           self.groupPrivileges = {}
-          (_ktype35, _vtype36, _size34 ) = iprot.readMapBegin() 
+          (_ktype35, _vtype36, _size34 ) = iprot.readMapBegin()
           for _i38 in xrange(_size34):
             _key39 = iprot.readString();
             _val40 = []
@@ -932,7 +984,7 @@ class PrincipalPrivilegeSet:
       elif fid == 3:
         if ftype == TType.MAP:
           self.rolePrivileges = {}
-          (_ktype48, _vtype49, _size47 ) = iprot.readMapBegin() 
+          (_ktype48, _vtype49, _size47 ) = iprot.readMapBegin()
           for _i51 in xrange(_size47):
             _key52 = iprot.readString();
             _val53 = []
@@ -996,6 +1048,13 @@ class PrincipalPrivilegeSet:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.userPrivileges)
+    value = (value * 31) ^ hash(self.groupPrivileges)
+    value = (value * 31) ^ hash(self.rolePrivileges)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1081,6 +1140,13 @@ class GrantRevokePrivilegeRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.requestType)
+    value = (value * 31) ^ hash(self.privileges)
+    value = (value * 31) ^ hash(self.revokeGrantOption)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1141,6 +1207,11 @@ class GrantRevokePrivilegeResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1225,6 +1296,13 @@ class Role:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.roleName)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.ownerName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1357,6 +1435,17 @@ class RolePrincipalGrant:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.roleName)
+    value = (value * 31) ^ hash(self.principalName)
+    value = (value * 31) ^ hash(self.principalType)
+    value = (value * 31) ^ hash(self.grantOption)
+    value = (value * 31) ^ hash(self.grantTime)
+    value = (value * 31) ^ hash(self.grantorName)
+    value = (value * 31) ^ hash(self.grantorPrincipalType)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1433,6 +1522,12 @@ class GetRoleGrantsForPrincipalRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.principal_name)
+    value = (value * 31) ^ hash(self.principal_type)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1504,6 +1599,11 @@ class GetRoleGrantsForPrincipalResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.principalGrants)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1566,6 +1666,11 @@ class GetPrincipalsInRoleRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.roleName)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1637,6 +1742,11 @@ class GetPrincipalsInRoleResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.principalGrants)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1769,6 +1879,17 @@ class GrantRevokeRoleRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.requestType)
+    value = (value * 31) ^ hash(self.roleName)
+    value = (value * 31) ^ hash(self.principalName)
+    value = (value * 31) ^ hash(self.principalType)
+    value = (value * 31) ^ hash(self.grantor)
+    value = (value * 31) ^ hash(self.grantorType)
+    value = (value * 31) ^ hash(self.grantOption)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1829,6 +1950,11 @@ class GrantRevokeRoleResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.success)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -1899,7 +2025,7 @@ class Database:
       elif fid == 4:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype84, _vtype85, _size83 ) = iprot.readMapBegin() 
+          (_ktype84, _vtype85, _size83 ) = iprot.readMapBegin()
           for _i87 in xrange(_size83):
             _key88 = iprot.readString();
             _val89 = iprot.readString();
@@ -1972,6 +2098,17 @@ class Database:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.name)
+    value = (value * 31) ^ hash(self.description)
+    value = (value * 31) ^ hash(self.locationUri)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.privileges)
+    value = (value * 31) ^ hash(self.ownerName)
+    value = (value * 31) ^ hash(self.ownerType)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2025,7 +2162,7 @@ class SerDeInfo:
       elif fid == 3:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype93, _vtype94, _size92 ) = iprot.readMapBegin() 
+          (_ktype93, _vtype94, _size92 ) = iprot.readMapBegin()
           for _i96 in xrange(_size92):
             _key97 = iprot.readString();
             _val98 = iprot.readString();
@@ -2066,6 +2203,13 @@ class SerDeInfo:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.name)
+    value = (value * 31) ^ hash(self.serializationLib)
+    value = (value * 31) ^ hash(self.parameters)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2138,6 +2282,12 @@ class Order:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.col)
+    value = (value * 31) ^ hash(self.order)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2206,7 +2356,7 @@ class SkewedInfo:
       elif fid == 3:
         if ftype == TType.MAP:
           self.skewedColValueLocationMaps = {}
-          (_ktype120, _vtype121, _size119 ) = iprot.readMapBegin() 
+          (_ktype120, _vtype121, _size119 ) = iprot.readMapBegin()
           for _i123 in xrange(_size119):
             _key124 = []
             (_etype129, _size126) = iprot.readListBegin()
@@ -2264,6 +2414,13 @@ class SkewedInfo:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.skewedColNames)
+    value = (value * 31) ^ hash(self.skewedColValues)
+    value = (value * 31) ^ hash(self.skewedColValueLocationMaps)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2397,7 +2554,7 @@ class StorageDescriptor:
       elif fid == 10:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype157, _vtype158, _size156 ) = iprot.readMapBegin() 
+          (_ktype157, _vtype158, _size156 ) = iprot.readMapBegin()
           for _i160 in xrange(_size156):
             _key161 = iprot.readString();
             _val162 = iprot.readString();
@@ -2494,6 +2651,22 @@ class StorageDescriptor:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.cols)
+    value = (value * 31) ^ hash(self.location)
+    value = (value * 31) ^ hash(self.inputFormat)
+    value = (value * 31) ^ hash(self.outputFormat)
+    value = (value * 31) ^ hash(self.compressed)
+    value = (value * 31) ^ hash(self.numBuckets)
+    value = (value * 31) ^ hash(self.serdeInfo)
+    value = (value * 31) ^ hash(self.bucketCols)
+    value = (value * 31) ^ hash(self.sortCols)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.skewedInfo)
+    value = (value * 31) ^ hash(self.storedAsSubDirectories)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2617,7 +2790,7 @@ class Table:
       elif fid == 9:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype175, _vtype176, _size174 ) = iprot.readMapBegin() 
+          (_ktype175, _vtype176, _size174 ) = iprot.readMapBegin()
           for _i178 in xrange(_size174):
             _key179 = iprot.readString();
             _val180 = iprot.readString();
@@ -2731,6 +2904,24 @@ class Table:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.owner)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.lastAccessTime)
+    value = (value * 31) ^ hash(self.retention)
+    value = (value * 31) ^ hash(self.sd)
+    value = (value * 31) ^ hash(self.partitionKeys)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.viewOriginalText)
+    value = (value * 31) ^ hash(self.viewExpandedText)
+    value = (value * 31) ^ hash(self.tableType)
+    value = (value * 31) ^ hash(self.privileges)
+    value = (value * 31) ^ hash(self.temporary)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2825,7 +3016,7 @@ class Partition:
       elif fid == 7:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype191, _vtype192, _size190 ) = iprot.readMapBegin() 
+          (_ktype191, _vtype192, _size190 ) = iprot.readMapBegin()
           for _i194 in xrange(_size190):
             _key195 = iprot.readString();
             _val196 = iprot.readString();
@@ -2895,6 +3086,18 @@ class Partition:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.lastAccessTime)
+    value = (value * 31) ^ hash(self.sd)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.privileges)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -2972,7 +3175,7 @@ class PartitionWithoutSD:
       elif fid == 5:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype207, _vtype208, _size206 ) = iprot.readMapBegin() 
+          (_ktype207, _vtype208, _size206 ) = iprot.readMapBegin()
           for _i210 in xrange(_size206):
             _key211 = iprot.readString();
             _val212 = iprot.readString();
@@ -3034,6 +3237,16 @@ class PartitionWithoutSD:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.values)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.lastAccessTime)
+    value = (value * 31) ^ hash(self.relativePath)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.privileges)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3116,6 +3329,12 @@ class PartitionSpecWithSharedSD:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partitions)
+    value = (value * 31) ^ hash(self.sd)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3185,6 +3404,11 @@ class PartitionListComposingSpec:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partitions)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3295,6 +3519,15 @@ class PartitionSpec:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.rootPath)
+    value = (value * 31) ^ hash(self.sharedSDPartitionSpec)
+    value = (value * 31) ^ hash(self.partitionList)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3400,7 +3633,7 @@ class Index:
       elif fid == 9:
         if ftype == TType.MAP:
           self.parameters = {}
-          (_ktype231, _vtype232, _size230 ) = iprot.readMapBegin() 
+          (_ktype231, _vtype232, _size230 ) = iprot.readMapBegin()
           for _i234 in xrange(_size230):
             _key235 = iprot.readString();
             _val236 = iprot.readString();
@@ -3474,6 +3707,20 @@ class Index:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.indexName)
+    value = (value * 31) ^ hash(self.indexHandlerClass)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.origTableName)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.lastAccessTime)
+    value = (value * 31) ^ hash(self.indexTableName)
+    value = (value * 31) ^ hash(self.sd)
+    value = (value * 31) ^ hash(self.parameters)
+    value = (value * 31) ^ hash(self.deferredRebuild)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3564,6 +3811,13 @@ class BooleanColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.numTrues)
+    value = (value * 31) ^ hash(self.numFalses)
+    value = (value * 31) ^ hash(self.numNulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3664,6 +3918,14 @@ class DoubleColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lowValue)
+    value = (value * 31) ^ hash(self.highValue)
+    value = (value * 31) ^ hash(self.numNulls)
+    value = (value * 31) ^ hash(self.numDVs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3764,6 +4026,14 @@ class LongColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lowValue)
+    value = (value * 31) ^ hash(self.highValue)
+    value = (value * 31) ^ hash(self.numNulls)
+    value = (value * 31) ^ hash(self.numDVs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3868,6 +4138,14 @@ class StringColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.maxColLen)
+    value = (value * 31) ^ hash(self.avgColLen)
+    value = (value * 31) ^ hash(self.numNulls)
+    value = (value * 31) ^ hash(self.numDVs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -3958,6 +4236,13 @@ class BinaryColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.maxColLen)
+    value = (value * 31) ^ hash(self.avgColLen)
+    value = (value * 31) ^ hash(self.numNulls)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4035,6 +4320,12 @@ class Decimal:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.unscaled)
+    value = (value * 31) ^ hash(self.scale)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4137,6 +4428,14 @@ class DecimalColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lowValue)
+    value = (value * 31) ^ hash(self.highValue)
+    value = (value * 31) ^ hash(self.numNulls)
+    value = (value * 31) ^ hash(self.numDVs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4199,6 +4498,11 @@ class Date:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.daysSinceEpoch)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4301,6 +4605,14 @@ class DateColumnStatsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lowValue)
+    value = (value * 31) ^ hash(self.highValue)
+    value = (value * 31) ^ hash(self.numNulls)
+    value = (value * 31) ^ hash(self.numDVs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4440,6 +4752,17 @@ class ColumnStatisticsData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.booleanStats)
+    value = (value * 31) ^ hash(self.longStats)
+    value = (value * 31) ^ hash(self.doubleStats)
+    value = (value * 31) ^ hash(self.stringStats)
+    value = (value * 31) ^ hash(self.binaryStats)
+    value = (value * 31) ^ hash(self.decimalStats)
+    value = (value * 31) ^ hash(self.dateStats)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4531,6 +4854,13 @@ class ColumnStatisticsObj:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.colName)
+    value = (value * 31) ^ hash(self.colType)
+    value = (value * 31) ^ hash(self.statsData)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4645,6 +4975,15 @@ class ColumnStatisticsDesc:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.isTblLevel)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.partName)
+    value = (value * 31) ^ hash(self.lastAnalyzed)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4731,6 +5070,12 @@ class ColumnStatistics:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.statsDesc)
+    value = (value * 31) ^ hash(self.statsObj)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4816,6 +5161,12 @@ class AggrStats:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.colStats)
+    value = (value * 31) ^ hash(self.partsFound)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4887,6 +5238,11 @@ class SetPartitionsStatsRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.colStats)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -4938,7 +5294,7 @@ class Schema:
       elif fid == 2:
         if ftype == TType.MAP:
           self.properties = {}
-          (_ktype267, _vtype268, _size266 ) = iprot.readMapBegin() 
+          (_ktype267, _vtype268, _size266 ) = iprot.readMapBegin()
           for _i270 in xrange(_size266):
             _key271 = iprot.readString();
             _val272 = iprot.readString();
@@ -4978,6 +5334,12 @@ class Schema:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.fieldSchemas)
+    value = (value * 31) ^ hash(self.properties)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5015,7 +5377,7 @@ class EnvironmentContext:
       if fid == 1:
         if ftype == TType.MAP:
           self.properties = {}
-          (_ktype277, _vtype278, _size276 ) = iprot.readMapBegin() 
+          (_ktype277, _vtype278, _size276 ) = iprot.readMapBegin()
           for _i280 in xrange(_size276):
             _key281 = iprot.readString();
             _val282 = iprot.readString();
@@ -5048,6 +5410,11 @@ class EnvironmentContext:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.properties)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5133,6 +5500,12 @@ class PartitionsByExprResult:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partitions)
+    value = (value * 31) ^ hash(self.hasUnknownPartitions)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5247,6 +5620,15 @@ class PartitionsByExprRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tblName)
+    value = (value * 31) ^ hash(self.expr)
+    value = (value * 31) ^ hash(self.defaultPartitionName)
+    value = (value * 31) ^ hash(self.maxParts)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5318,6 +5700,11 @@ class TableStatsResult:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.tableStats)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5355,7 +5742,7 @@ class PartitionsStatsResult:
       if fid == 1:
         if ftype == TType.MAP:
           self.partStats = {}
-          (_ktype300, _vtype301, _size299 ) = iprot.readMapBegin() 
+          (_ktype300, _vtype301, _size299 ) = iprot.readMapBegin()
           for _i303 in xrange(_size299):
             _key304 = iprot.readString();
             _val305 = []
@@ -5399,6 +5786,11 @@ class PartitionsStatsResult:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partStats)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5497,6 +5889,13 @@ class TableStatsRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tblName)
+    value = (value * 31) ^ hash(self.colNames)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5617,6 +6016,14 @@ class PartitionsStatsRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tblName)
+    value = (value * 31) ^ hash(self.colNames)
+    value = (value * 31) ^ hash(self.partNames)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5686,6 +6093,11 @@ class AddPartitionsResult:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partitions)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5811,6 +6223,15 @@ class AddPartitionsRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tblName)
+    value = (value * 31) ^ hash(self.parts)
+    value = (value * 31) ^ hash(self.ifNotExists)
+    value = (value * 31) ^ hash(self.needResult)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5880,6 +6301,11 @@ class DropPartitionsResult:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.partitions)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -5954,6 +6380,12 @@ class DropPartitionsExpr:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.expr)
+    value = (value * 31) ^ hash(self.partArchiveLevel)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6043,6 +6475,12 @@ class RequestPartsSpec:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.names)
+    value = (value * 31) ^ hash(self.exprs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6195,6 +6633,18 @@ class DropPartitionsRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tblName)
+    value = (value * 31) ^ hash(self.parts)
+    value = (value * 31) ^ hash(self.deleteData)
+    value = (value * 31) ^ hash(self.ifExists)
+    value = (value * 31) ^ hash(self.ignoreProtection)
+    value = (value * 31) ^ hash(self.environmentContext)
+    value = (value * 31) ^ hash(self.needResult)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6267,6 +6717,12 @@ class ResourceUri:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.resourceType)
+    value = (value * 31) ^ hash(self.uri)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6420,6 +6876,18 @@ class Function:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.functionName)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.className)
+    value = (value * 31) ^ hash(self.ownerName)
+    value = (value * 31) ^ hash(self.ownerType)
+    value = (value * 31) ^ hash(self.createTime)
+    value = (value * 31) ^ hash(self.functionType)
+    value = (value * 31) ^ hash(self.resourceUris)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6524,6 +6992,14 @@ class TxnInfo:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.id)
+    value = (value * 31) ^ hash(self.state)
+    value = (value * 31) ^ hash(self.user)
+    value = (value * 31) ^ hash(self.hostname)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6609,6 +7085,12 @@ class GetOpenTxnsInfoResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txn_high_water_mark)
+    value = (value * 31) ^ hash(self.open_txns)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6693,6 +7175,12 @@ class GetOpenTxnsResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txn_high_water_mark)
+    value = (value * 31) ^ hash(self.open_txns)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6783,6 +7271,13 @@ class OpenTxnRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.num_txns)
+    value = (value * 31) ^ hash(self.user)
+    value = (value * 31) ^ hash(self.hostname)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6853,6 +7348,11 @@ class OpenTxnsResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txn_ids)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6915,6 +7415,11 @@ class AbortTxnRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txnid)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -6977,6 +7482,11 @@ class CommitTxnRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txnid)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7091,6 +7601,15 @@ class LockComponent:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.level)
+    value = (value * 31) ^ hash(self.dbname)
+    value = (value * 31) ^ hash(self.tablename)
+    value = (value * 31) ^ hash(self.partitionname)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7202,6 +7721,14 @@ class LockRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.component)
+    value = (value * 31) ^ hash(self.txnid)
+    value = (value * 31) ^ hash(self.user)
+    value = (value * 31) ^ hash(self.hostname)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7278,6 +7805,12 @@ class LockResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lockid)
+    value = (value * 31) ^ hash(self.state)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7340,6 +7873,11 @@ class CheckLockRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lockid)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7402,6 +7940,11 @@ class UnlockRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lockid)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7444,6 +7987,10 @@ class ShowLocksRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7638,6 +8185,21 @@ class ShowLocksResponseElement:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lockid)
+    value = (value * 31) ^ hash(self.dbname)
+    value = (value * 31) ^ hash(self.tablename)
+    value = (value * 31) ^ hash(self.partname)
+    value = (value * 31) ^ hash(self.state)
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.txnid)
+    value = (value * 31) ^ hash(self.lastheartbeat)
+    value = (value * 31) ^ hash(self.acquiredat)
+    value = (value * 31) ^ hash(self.user)
+    value = (value * 31) ^ hash(self.hostname)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7707,6 +8269,11 @@ class ShowLocksResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.locks)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7779,6 +8346,12 @@ class HeartbeatRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lockid)
+    value = (value * 31) ^ hash(self.txnid)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7855,6 +8428,12 @@ class HeartbeatTxnRangeRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.min)
+    value = (value * 31) ^ hash(self.max)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -7947,6 +8526,12 @@ class HeartbeatTxnRangeResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.aborted)
+    value = (value * 31) ^ hash(self.nosuch)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8061,6 +8646,15 @@ class CompactionRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbname)
+    value = (value * 31) ^ hash(self.tablename)
+    value = (value * 31) ^ hash(self.partitionname)
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.runas)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8103,6 +8697,10 @@ class ShowCompactRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8255,6 +8853,18 @@ class ShowCompactResponseElement:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.dbname)
+    value = (value * 31) ^ hash(self.tablename)
+    value = (value * 31) ^ hash(self.partitionname)
+    value = (value * 31) ^ hash(self.type)
+    value = (value * 31) ^ hash(self.state)
+    value = (value * 31) ^ hash(self.workerid)
+    value = (value * 31) ^ hash(self.start)
+    value = (value * 31) ^ hash(self.runAs)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8326,6 +8936,11 @@ class ShowCompactResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.compacts)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8438,6 +9053,14 @@ class AddDynamicPartitions:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.txnid)
+    value = (value * 31) ^ hash(self.dbname)
+    value = (value * 31) ^ hash(self.tablename)
+    value = (value * 31) ^ hash(self.partitionnames)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8512,6 +9135,12 @@ class NotificationEventRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.lastEvent)
+    value = (value * 31) ^ hash(self.maxEvents)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8640,6 +9269,16 @@ class NotificationEvent:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.eventId)
+    value = (value * 31) ^ hash(self.eventTime)
+    value = (value * 31) ^ hash(self.eventType)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8711,6 +9350,11 @@ class NotificationEventResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.events)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8773,6 +9417,11 @@ class CurrentNotificationEventId:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.eventId)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8843,6 +9492,11 @@ class InsertEventRequestData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.filesAdded)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -8904,6 +9558,11 @@ class FireEventRequestData:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.insertData)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9025,6 +9684,15 @@ class FireEventRequest:
     return
 
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.successful)
+    value = (value * 31) ^ hash(self.data)
+    value = (value * 31) ^ hash(self.dbName)
+    value = (value * 31) ^ hash(self.tableName)
+    value = (value * 31) ^ hash(self.partitionVals)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9067,6 +9735,10 @@ class FireEventResponse:
     return
 
 
+  def __hash__(self):
+    value = 17
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9130,6 +9802,11 @@ class MetaException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9193,6 +9870,11 @@ class UnknownTableException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9256,6 +9938,11 @@ class UnknownDBException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9319,6 +10006,11 @@ class AlreadyExistsException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9382,6 +10074,11 @@ class InvalidPartitionException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9445,6 +10142,11 @@ class UnknownPartitionException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9508,6 +10210,11 @@ class InvalidObjectException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9571,6 +10278,11 @@ class NoSuchObjectException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9634,6 +10346,11 @@ class IndexAlreadyExistsException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9697,6 +10414,11 @@ class InvalidOperationException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9760,6 +10482,11 @@ class ConfigValSecurityException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9823,6 +10550,11 @@ class InvalidInputException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9886,6 +10618,11 @@ class NoSuchTxnException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -9949,6 +10686,11 @@ class TxnAbortedException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -10012,6 +10754,11 @@ class TxnOpenException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]
@@ -10075,6 +10822,11 @@ class NoSuchLockException(TException):
   def __str__(self):
     return repr(self)
 
+  def __hash__(self):
+    value = 17
+    value = (value * 31) ^ hash(self.message)
+    return value
+
   def __repr__(self):
     L = ['%s=%r' % (key, value)
       for key, value in self.__dict__.iteritems()]

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-rb/hive_metastore_constants.rb
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-rb/hive_metastore_constants.rb b/metastore/src/gen/thrift/gen-rb/hive_metastore_constants.rb
index 3208ecd..7ef6f43 100644
--- a/metastore/src/gen/thrift/gen-rb/hive_metastore_constants.rb
+++ b/metastore/src/gen/thrift/gen-rb/hive_metastore_constants.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb b/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
index 4ae5d53..a1622ae 100644
--- a/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
+++ b/metastore/src/gen/thrift/gen-rb/hive_metastore_types.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb b/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
index edc00d3..5645fe2 100644
--- a/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
+++ b/metastore/src/gen/thrift/gen-rb/thrift_hive_metastore.rb
@@ -1,5 +1,5 @@
 #
-# Autogenerated by Thrift Compiler (0.9.0)
+# Autogenerated by Thrift Compiler (0.9.2)
 #
 # DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 #

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/if/queryplan.thrift
----------------------------------------------------------------------
diff --git a/ql/if/queryplan.thrift b/ql/if/queryplan.thrift
index c8dfa35..cc9af94 100644
--- a/ql/if/queryplan.thrift
+++ b/ql/if/queryplan.thrift
@@ -60,6 +60,7 @@ enum OperatorType {
   ORCFILEMERGE,
   RCFILEMERGE,
   MERGEJOIN,
+  SPARKPRUNINGSINK,
 }
 
 struct Operator {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-cpp/queryplan_constants.cpp
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-cpp/queryplan_constants.cpp b/ql/src/gen/thrift/gen-cpp/queryplan_constants.cpp
index 4f9aeaf..280edbe 100644
--- a/ql/src/gen/thrift/gen-cpp/queryplan_constants.cpp
+++ b/ql/src/gen/thrift/gen-cpp/queryplan_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/gen/thrift/gen-cpp/queryplan_constants.h
----------------------------------------------------------------------
diff --git a/ql/src/gen/thrift/gen-cpp/queryplan_constants.h b/ql/src/gen/thrift/gen-cpp/queryplan_constants.h
index 5dce5dd..6bee48d 100644
--- a/ql/src/gen/thrift/gen-cpp/queryplan_constants.h
+++ b/ql/src/gen/thrift/gen-cpp/queryplan_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[30/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-php/metastore/Types.php
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-php/metastore/Types.php b/metastore/src/gen/thrift/gen-php/metastore/Types.php
index a1ce8cd..31b951e 100644
--- a/metastore/src/gen/thrift/gen-php/metastore/Types.php
+++ b/metastore/src/gen/thrift/gen-php/metastore/Types.php
@@ -2,7 +2,7 @@
 namespace metastore;
 
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -13,6 +13,7 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
@@ -145,7 +146,13 @@ final class ResourceType {
 class Version {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $version = null;
+  /**
+   * @var string
+   */
   public $comments = null;
 
   public function __construct($vals=null) {
@@ -237,8 +244,17 @@ class Version {
 class FieldSchema {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $name = null;
+  /**
+   * @var string
+   */
   public $type = null;
+  /**
+   * @var string
+   */
   public $comment = null;
 
   public function __construct($vals=null) {
@@ -349,9 +365,21 @@ class FieldSchema {
 class Type {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $name = null;
+  /**
+   * @var string
+   */
   public $type1 = null;
+  /**
+   * @var string
+   */
   public $type2 = null;
+  /**
+   * @var \metastore\FieldSchema[]
+   */
   public $fields = null;
 
   public function __construct($vals=null) {
@@ -509,10 +537,25 @@ class Type {
 class HiveObjectRef {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $objectType = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $objectName = null;
+  /**
+   * @var string[]
+   */
   public $partValues = null;
+  /**
+   * @var string
+   */
   public $columnName = null;
 
   public function __construct($vals=null) {
@@ -687,10 +730,25 @@ class HiveObjectRef {
 class PrivilegeGrantInfo {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $privilege = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var string
+   */
   public $grantor = null;
+  /**
+   * @var int
+   */
   public $grantorType = null;
+  /**
+   * @var bool
+   */
   public $grantOption = null;
 
   public function __construct($vals=null) {
@@ -839,9 +897,21 @@ class PrivilegeGrantInfo {
 class HiveObjectPrivilege {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\HiveObjectRef
+   */
   public $hiveObject = null;
+  /**
+   * @var string
+   */
   public $principalName = null;
+  /**
+   * @var int
+   */
   public $principalType = null;
+  /**
+   * @var \metastore\PrivilegeGrantInfo
+   */
   public $grantInfo = null;
 
   public function __construct($vals=null) {
@@ -981,6 +1051,9 @@ class HiveObjectPrivilege {
 class PrivilegeBag {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\HiveObjectPrivilege[]
+   */
   public $privileges = null;
 
   public function __construct($vals=null) {
@@ -1081,8 +1154,17 @@ class PrivilegeBag {
 class PrincipalPrivilegeSet {
   static $_TSPEC;
 
+  /**
+   * @var array
+   */
   public $userPrivileges = null;
+  /**
+   * @var array
+   */
   public $groupPrivileges = null;
+  /**
+   * @var array
+   */
   public $rolePrivileges = null;
 
   public function __construct($vals=null) {
@@ -1370,8 +1452,17 @@ class PrincipalPrivilegeSet {
 class GrantRevokePrivilegeRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $requestType = null;
+  /**
+   * @var \metastore\PrivilegeBag
+   */
   public $privileges = null;
+  /**
+   * @var bool
+   */
   public $revokeGrantOption = null;
 
   public function __construct($vals=null) {
@@ -1487,6 +1578,9 @@ class GrantRevokePrivilegeRequest {
 class GrantRevokePrivilegeResponse {
   static $_TSPEC;
 
+  /**
+   * @var bool
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -1559,8 +1653,17 @@ class GrantRevokePrivilegeResponse {
 class Role {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $roleName = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var string
+   */
   public $ownerName = null;
 
   public function __construct($vals=null) {
@@ -1671,12 +1774,33 @@ class Role {
 class RolePrincipalGrant {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $roleName = null;
+  /**
+   * @var string
+   */
   public $principalName = null;
+  /**
+   * @var int
+   */
   public $principalType = null;
+  /**
+   * @var bool
+   */
   public $grantOption = null;
+  /**
+   * @var int
+   */
   public $grantTime = null;
+  /**
+   * @var string
+   */
   public $grantorName = null;
+  /**
+   * @var int
+   */
   public $grantorPrincipalType = null;
 
   public function __construct($vals=null) {
@@ -1863,7 +1987,13 @@ class RolePrincipalGrant {
 class GetRoleGrantsForPrincipalRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $principal_name = null;
+  /**
+   * @var int
+   */
   public $principal_type = null;
 
   public function __construct($vals=null) {
@@ -1955,6 +2085,9 @@ class GetRoleGrantsForPrincipalRequest {
 class GetRoleGrantsForPrincipalResponse {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\RolePrincipalGrant[]
+   */
   public $principalGrants = null;
 
   public function __construct($vals=null) {
@@ -2055,6 +2188,9 @@ class GetRoleGrantsForPrincipalResponse {
 class GetPrincipalsInRoleRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $roleName = null;
 
   public function __construct($vals=null) {
@@ -2127,6 +2263,9 @@ class GetPrincipalsInRoleRequest {
 class GetPrincipalsInRoleResponse {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\RolePrincipalGrant[]
+   */
   public $principalGrants = null;
 
   public function __construct($vals=null) {
@@ -2227,12 +2366,33 @@ class GetPrincipalsInRoleResponse {
 class GrantRevokeRoleRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $requestType = null;
+  /**
+   * @var string
+   */
   public $roleName = null;
+  /**
+   * @var string
+   */
   public $principalName = null;
+  /**
+   * @var int
+   */
   public $principalType = null;
+  /**
+   * @var string
+   */
   public $grantor = null;
+  /**
+   * @var int
+   */
   public $grantorType = null;
+  /**
+   * @var bool
+   */
   public $grantOption = null;
 
   public function __construct($vals=null) {
@@ -2419,6 +2579,9 @@ class GrantRevokeRoleRequest {
 class GrantRevokeRoleResponse {
   static $_TSPEC;
 
+  /**
+   * @var bool
+   */
   public $success = null;
 
   public function __construct($vals=null) {
@@ -2491,12 +2654,33 @@ class GrantRevokeRoleResponse {
 class Database {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $name = null;
+  /**
+   * @var string
+   */
   public $description = null;
+  /**
+   * @var string
+   */
   public $locationUri = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var \metastore\PrincipalPrivilegeSet
+   */
   public $privileges = null;
+  /**
+   * @var string
+   */
   public $ownerName = null;
+  /**
+   * @var int
+   */
   public $ownerType = null;
 
   public function __construct($vals=null) {
@@ -2722,8 +2906,17 @@ class Database {
 class SerDeInfo {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $name = null;
+  /**
+   * @var string
+   */
   public $serializationLib = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
 
   public function __construct($vals=null) {
@@ -2868,7 +3061,13 @@ class SerDeInfo {
 class Order {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $col = null;
+  /**
+   * @var int
+   */
   public $order = null;
 
   public function __construct($vals=null) {
@@ -2960,8 +3159,17 @@ class Order {
 class SkewedInfo {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $skewedColNames = null;
+  /**
+   * @var (string[])[]
+   */
   public $skewedColValues = null;
+  /**
+   * @var array
+   */
   public $skewedColValueLocationMaps = null;
 
   public function __construct($vals=null) {
@@ -3204,17 +3412,53 @@ class SkewedInfo {
 class StorageDescriptor {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\FieldSchema[]
+   */
   public $cols = null;
+  /**
+   * @var string
+   */
   public $location = null;
+  /**
+   * @var string
+   */
   public $inputFormat = null;
+  /**
+   * @var string
+   */
   public $outputFormat = null;
+  /**
+   * @var bool
+   */
   public $compressed = null;
+  /**
+   * @var int
+   */
   public $numBuckets = null;
+  /**
+   * @var \metastore\SerDeInfo
+   */
   public $serdeInfo = null;
+  /**
+   * @var string[]
+   */
   public $bucketCols = null;
+  /**
+   * @var \metastore\Order[]
+   */
   public $sortCols = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var \metastore\SkewedInfo
+   */
   public $skewedInfo = null;
+  /**
+   * @var bool
+   */
   public $storedAsSubDirectories = null;
 
   public function __construct($vals=null) {
@@ -3622,19 +3866,61 @@ class StorageDescriptor {
 class Table {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $owner = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var int
+   */
   public $lastAccessTime = null;
+  /**
+   * @var int
+   */
   public $retention = null;
+  /**
+   * @var \metastore\StorageDescriptor
+   */
   public $sd = null;
+  /**
+   * @var \metastore\FieldSchema[]
+   */
   public $partitionKeys = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var string
+   */
   public $viewOriginalText = null;
+  /**
+   * @var string
+   */
   public $viewExpandedText = null;
+  /**
+   * @var string
+   */
   public $tableType = null;
+  /**
+   * @var \metastore\PrincipalPrivilegeSet
+   */
   public $privileges = null;
+  /**
+   * @var bool
+   */
   public $temporary = false;
 
   public function __construct($vals=null) {
@@ -4026,13 +4312,37 @@ class Table {
 class Partition {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $values = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var int
+   */
   public $lastAccessTime = null;
+  /**
+   * @var \metastore\StorageDescriptor
+   */
   public $sd = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var \metastore\PrincipalPrivilegeSet
+   */
   public $privileges = null;
 
   public function __construct($vals=null) {
@@ -4308,11 +4618,29 @@ class Partition {
 class PartitionWithoutSD {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $values = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var int
+   */
   public $lastAccessTime = null;
+  /**
+   * @var string
+   */
   public $relativePath = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var \metastore\PrincipalPrivilegeSet
+   */
   public $privileges = null;
 
   public function __construct($vals=null) {
@@ -4545,7 +4873,13 @@ class PartitionWithoutSD {
 class PartitionSpecWithSharedSD {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\PartitionWithoutSD[]
+   */
   public $partitions = null;
+  /**
+   * @var \metastore\StorageDescriptor
+   */
   public $sd = null;
 
   public function __construct($vals=null) {
@@ -4670,6 +5004,9 @@ class PartitionSpecWithSharedSD {
 class PartitionListComposingSpec {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Partition[]
+   */
   public $partitions = null;
 
   public function __construct($vals=null) {
@@ -4770,10 +5107,25 @@ class PartitionListComposingSpec {
 class PartitionSpec {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var string
+   */
   public $rootPath = null;
+  /**
+   * @var \metastore\PartitionSpecWithSharedSD
+   */
   public $sharedSDPartitionSpec = null;
+  /**
+   * @var \metastore\PartitionListComposingSpec
+   */
   public $partitionList = null;
 
   public function __construct($vals=null) {
@@ -4932,15 +5284,45 @@ class PartitionSpec {
 class Index {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $indexName = null;
+  /**
+   * @var string
+   */
   public $indexHandlerClass = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $origTableName = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var int
+   */
   public $lastAccessTime = null;
+  /**
+   * @var string
+   */
   public $indexTableName = null;
+  /**
+   * @var \metastore\StorageDescriptor
+   */
   public $sd = null;
+  /**
+   * @var array
+   */
   public $parameters = null;
+  /**
+   * @var bool
+   */
   public $deferredRebuild = null;
 
   public function __construct($vals=null) {
@@ -5223,8 +5605,17 @@ class Index {
 class BooleanColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $numTrues = null;
+  /**
+   * @var int
+   */
   public $numFalses = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
 
   public function __construct($vals=null) {
@@ -5335,9 +5726,21 @@ class BooleanColumnStatsData {
 class DoubleColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var double
+   */
   public $lowValue = null;
+  /**
+   * @var double
+   */
   public $highValue = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
+  /**
+   * @var int
+   */
   public $numDVs = null;
 
   public function __construct($vals=null) {
@@ -5467,9 +5870,21 @@ class DoubleColumnStatsData {
 class LongColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lowValue = null;
+  /**
+   * @var int
+   */
   public $highValue = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
+  /**
+   * @var int
+   */
   public $numDVs = null;
 
   public function __construct($vals=null) {
@@ -5599,9 +6014,21 @@ class LongColumnStatsData {
 class StringColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $maxColLen = null;
+  /**
+   * @var double
+   */
   public $avgColLen = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
+  /**
+   * @var int
+   */
   public $numDVs = null;
 
   public function __construct($vals=null) {
@@ -5731,8 +6158,17 @@ class StringColumnStatsData {
 class BinaryColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $maxColLen = null;
+  /**
+   * @var double
+   */
   public $avgColLen = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
 
   public function __construct($vals=null) {
@@ -5843,7 +6279,13 @@ class BinaryColumnStatsData {
 class Decimal {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $unscaled = null;
+  /**
+   * @var int
+   */
   public $scale = null;
 
   public function __construct($vals=null) {
@@ -5935,9 +6377,21 @@ class Decimal {
 class DecimalColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Decimal
+   */
   public $lowValue = null;
+  /**
+   * @var \metastore\Decimal
+   */
   public $highValue = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
+  /**
+   * @var int
+   */
   public $numDVs = null;
 
   public function __construct($vals=null) {
@@ -6077,6 +6531,9 @@ class DecimalColumnStatsData {
 class Date {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $daysSinceEpoch = null;
 
   public function __construct($vals=null) {
@@ -6149,9 +6606,21 @@ class Date {
 class DateColumnStatsData {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Date
+   */
   public $lowValue = null;
+  /**
+   * @var \metastore\Date
+   */
   public $highValue = null;
+  /**
+   * @var int
+   */
   public $numNulls = null;
+  /**
+   * @var int
+   */
   public $numDVs = null;
 
   public function __construct($vals=null) {
@@ -6291,12 +6760,33 @@ class DateColumnStatsData {
 class ColumnStatisticsData {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\BooleanColumnStatsData
+   */
   public $booleanStats = null;
+  /**
+   * @var \metastore\LongColumnStatsData
+   */
   public $longStats = null;
+  /**
+   * @var \metastore\DoubleColumnStatsData
+   */
   public $doubleStats = null;
+  /**
+   * @var \metastore\StringColumnStatsData
+   */
   public $stringStats = null;
+  /**
+   * @var \metastore\BinaryColumnStatsData
+   */
   public $binaryStats = null;
+  /**
+   * @var \metastore\DecimalColumnStatsData
+   */
   public $decimalStats = null;
+  /**
+   * @var \metastore\DateColumnStatsData
+   */
   public $dateStats = null;
 
   public function __construct($vals=null) {
@@ -6518,8 +7008,17 @@ class ColumnStatisticsData {
 class ColumnStatisticsObj {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $colName = null;
+  /**
+   * @var string
+   */
   public $colType = null;
+  /**
+   * @var \metastore\ColumnStatisticsData
+   */
   public $statsData = null;
 
   public function __construct($vals=null) {
@@ -6635,10 +7134,25 @@ class ColumnStatisticsObj {
 class ColumnStatisticsDesc {
   static $_TSPEC;
 
+  /**
+   * @var bool
+   */
   public $isTblLevel = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var string
+   */
   public $partName = null;
+  /**
+   * @var int
+   */
   public $lastAnalyzed = null;
 
   public function __construct($vals=null) {
@@ -6787,7 +7301,13 @@ class ColumnStatisticsDesc {
 class ColumnStatistics {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ColumnStatisticsDesc
+   */
   public $statsDesc = null;
+  /**
+   * @var \metastore\ColumnStatisticsObj[]
+   */
   public $statsObj = null;
 
   public function __construct($vals=null) {
@@ -6912,7 +7432,13 @@ class ColumnStatistics {
 class AggrStats {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ColumnStatisticsObj[]
+   */
   public $colStats = null;
+  /**
+   * @var int
+   */
   public $partsFound = null;
 
   public function __construct($vals=null) {
@@ -7032,6 +7558,9 @@ class AggrStats {
 class SetPartitionsStatsRequest {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ColumnStatistics[]
+   */
   public $colStats = null;
 
   public function __construct($vals=null) {
@@ -7132,7 +7661,13 @@ class SetPartitionsStatsRequest {
 class Schema {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\FieldSchema[]
+   */
   public $fieldSchemas = null;
+  /**
+   * @var array
+   */
   public $properties = null;
 
   public function __construct($vals=null) {
@@ -7286,6 +7821,9 @@ class Schema {
 class EnvironmentContext {
   static $_TSPEC;
 
+  /**
+   * @var array
+   */
   public $properties = null;
 
   public function __construct($vals=null) {
@@ -7392,7 +7930,13 @@ class EnvironmentContext {
 class PartitionsByExprResult {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Partition[]
+   */
   public $partitions = null;
+  /**
+   * @var bool
+   */
   public $hasUnknownPartitions = null;
 
   public function __construct($vals=null) {
@@ -7512,10 +8056,25 @@ class PartitionsByExprResult {
 class PartitionsByExprRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tblName = null;
+  /**
+   * @var string
+   */
   public $expr = null;
+  /**
+   * @var string
+   */
   public $defaultPartitionName = null;
+  /**
+   * @var int
+   */
   public $maxParts = -1;
 
   public function __construct($vals=null) {
@@ -7664,6 +8223,9 @@ class PartitionsByExprRequest {
 class TableStatsResult {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ColumnStatisticsObj[]
+   */
   public $tableStats = null;
 
   public function __construct($vals=null) {
@@ -7764,6 +8326,9 @@ class TableStatsResult {
 class PartitionsStatsResult {
   static $_TSPEC;
 
+  /**
+   * @var array
+   */
   public $partStats = null;
 
   public function __construct($vals=null) {
@@ -7895,8 +8460,17 @@ class PartitionsStatsResult {
 class TableStatsRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tblName = null;
+  /**
+   * @var string[]
+   */
   public $colNames = null;
 
   public function __construct($vals=null) {
@@ -8033,9 +8607,21 @@ class TableStatsRequest {
 class PartitionsStatsRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tblName = null;
+  /**
+   * @var string[]
+   */
   public $colNames = null;
+  /**
+   * @var string[]
+   */
   public $partNames = null;
 
   public function __construct($vals=null) {
@@ -8217,6 +8803,9 @@ class PartitionsStatsRequest {
 class AddPartitionsResult {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Partition[]
+   */
   public $partitions = null;
 
   public function __construct($vals=null) {
@@ -8317,10 +8906,25 @@ class AddPartitionsResult {
 class AddPartitionsRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tblName = null;
+  /**
+   * @var \metastore\Partition[]
+   */
   public $parts = null;
+  /**
+   * @var bool
+   */
   public $ifNotExists = null;
+  /**
+   * @var bool
+   */
   public $needResult = true;
 
   public function __construct($vals=null) {
@@ -8497,6 +9101,9 @@ class AddPartitionsRequest {
 class DropPartitionsResult {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\Partition[]
+   */
   public $partitions = null;
 
   public function __construct($vals=null) {
@@ -8597,7 +9204,13 @@ class DropPartitionsResult {
 class DropPartitionsExpr {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $expr = null;
+  /**
+   * @var int
+   */
   public $partArchiveLevel = null;
 
   public function __construct($vals=null) {
@@ -8689,7 +9302,13 @@ class DropPartitionsExpr {
 class RequestPartsSpec {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $names = null;
+  /**
+   * @var \metastore\DropPartitionsExpr[]
+   */
   public $exprs = null;
 
   public function __construct($vals=null) {
@@ -8835,13 +9454,37 @@ class RequestPartsSpec {
 class DropPartitionsRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tblName = null;
+  /**
+   * @var \metastore\RequestPartsSpec
+   */
   public $parts = null;
+  /**
+   * @var bool
+   */
   public $deleteData = null;
+  /**
+   * @var bool
+   */
   public $ifExists = true;
+  /**
+   * @var bool
+   */
   public $ignoreProtection = null;
+  /**
+   * @var \metastore\EnvironmentContext
+   */
   public $environmentContext = null;
+  /**
+   * @var bool
+   */
   public $needResult = true;
 
   public function __construct($vals=null) {
@@ -9057,7 +9700,13 @@ class DropPartitionsRequest {
 class ResourceUri {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $resourceType = null;
+  /**
+   * @var string
+   */
   public $uri = null;
 
   public function __construct($vals=null) {
@@ -9149,13 +9798,37 @@ class ResourceUri {
 class Function {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $functionName = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $className = null;
+  /**
+   * @var string
+   */
   public $ownerName = null;
+  /**
+   * @var int
+   */
   public $ownerType = null;
+  /**
+   * @var int
+   */
   public $createTime = null;
+  /**
+   * @var int
+   */
   public $functionType = null;
+  /**
+   * @var \metastore\ResourceUri[]
+   */
   public $resourceUris = null;
 
   public function __construct($vals=null) {
@@ -9389,9 +10062,21 @@ class Function {
 class TxnInfo {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $id = null;
+  /**
+   * @var int
+   */
   public $state = null;
+  /**
+   * @var string
+   */
   public $user = null;
+  /**
+   * @var string
+   */
   public $hostname = null;
 
   public function __construct($vals=null) {
@@ -9521,7 +10206,13 @@ class TxnInfo {
 class GetOpenTxnsInfoResponse {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $txn_high_water_mark = null;
+  /**
+   * @var \metastore\TxnInfo[]
+   */
   public $open_txns = null;
 
   public function __construct($vals=null) {
@@ -9641,7 +10332,13 @@ class GetOpenTxnsInfoResponse {
 class GetOpenTxnsResponse {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $txn_high_water_mark = null;
+  /**
+   * @var int[]
+   */
   public $open_txns = null;
 
   public function __construct($vals=null) {
@@ -9767,8 +10464,17 @@ class GetOpenTxnsResponse {
 class OpenTxnRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $num_txns = null;
+  /**
+   * @var string
+   */
   public $user = null;
+  /**
+   * @var string
+   */
   public $hostname = null;
 
   public function __construct($vals=null) {
@@ -9879,6 +10585,9 @@ class OpenTxnRequest {
 class OpenTxnsResponse {
   static $_TSPEC;
 
+  /**
+   * @var int[]
+   */
   public $txn_ids = null;
 
   public function __construct($vals=null) {
@@ -9977,6 +10686,9 @@ class OpenTxnsResponse {
 class AbortTxnRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $txnid = null;
 
   public function __construct($vals=null) {
@@ -10049,6 +10761,9 @@ class AbortTxnRequest {
 class CommitTxnRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $txnid = null;
 
   public function __construct($vals=null) {
@@ -10121,10 +10836,25 @@ class CommitTxnRequest {
 class LockComponent {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $type = null;
+  /**
+   * @var int
+   */
   public $level = null;
+  /**
+   * @var string
+   */
   public $dbname = null;
+  /**
+   * @var string
+   */
   public $tablename = null;
+  /**
+   * @var string
+   */
   public $partitionname = null;
 
   public function __construct($vals=null) {
@@ -10273,9 +11003,21 @@ class LockComponent {
 class LockRequest {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\LockComponent[]
+   */
   public $component = null;
+  /**
+   * @var int
+   */
   public $txnid = null;
+  /**
+   * @var string
+   */
   public $user = null;
+  /**
+   * @var string
+   */
   public $hostname = null;
 
   public function __construct($vals=null) {
@@ -10433,7 +11175,13 @@ class LockRequest {
 class LockResponse {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lockid = null;
+  /**
+   * @var int
+   */
   public $state = null;
 
   public function __construct($vals=null) {
@@ -10525,6 +11273,9 @@ class LockResponse {
 class CheckLockRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lockid = null;
 
   public function __construct($vals=null) {
@@ -10597,6 +11348,9 @@ class CheckLockRequest {
 class UnlockRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lockid = null;
 
   public function __construct($vals=null) {
@@ -10719,16 +11473,49 @@ class ShowLocksRequest {
 class ShowLocksResponseElement {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lockid = null;
+  /**
+   * @var string
+   */
   public $dbname = null;
+  /**
+   * @var string
+   */
   public $tablename = null;
+  /**
+   * @var string
+   */
   public $partname = null;
+  /**
+   * @var int
+   */
   public $state = null;
+  /**
+   * @var int
+   */
   public $type = null;
+  /**
+   * @var int
+   */
   public $txnid = null;
+  /**
+   * @var int
+   */
   public $lastheartbeat = null;
+  /**
+   * @var int
+   */
   public $acquiredat = null;
+  /**
+   * @var string
+   */
   public $user = null;
+  /**
+   * @var string
+   */
   public $hostname = null;
 
   public function __construct($vals=null) {
@@ -10991,6 +11778,9 @@ class ShowLocksResponseElement {
 class ShowLocksResponse {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ShowLocksResponseElement[]
+   */
   public $locks = null;
 
   public function __construct($vals=null) {
@@ -11091,7 +11881,13 @@ class ShowLocksResponse {
 class HeartbeatRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lockid = null;
+  /**
+   * @var int
+   */
   public $txnid = null;
 
   public function __construct($vals=null) {
@@ -11183,7 +11979,13 @@ class HeartbeatRequest {
 class HeartbeatTxnRangeRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $min = null;
+  /**
+   * @var int
+   */
   public $max = null;
 
   public function __construct($vals=null) {
@@ -11275,7 +12077,13 @@ class HeartbeatTxnRangeRequest {
 class HeartbeatTxnRangeResponse {
   static $_TSPEC;
 
+  /**
+   * @var int[]
+   */
   public $aborted = null;
+  /**
+   * @var int[]
+   */
   public $nosuch = null;
 
   public function __construct($vals=null) {
@@ -11435,10 +12243,25 @@ class HeartbeatTxnRangeResponse {
 class CompactionRequest {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbname = null;
+  /**
+   * @var string
+   */
   public $tablename = null;
+  /**
+   * @var string
+   */
   public $partitionname = null;
+  /**
+   * @var int
+   */
   public $type = null;
+  /**
+   * @var string
+   */
   public $runas = null;
 
   public function __construct($vals=null) {
@@ -11637,13 +12460,37 @@ class ShowCompactRequest {
 class ShowCompactResponseElement {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $dbname = null;
+  /**
+   * @var string
+   */
   public $tablename = null;
+  /**
+   * @var string
+   */
   public $partitionname = null;
+  /**
+   * @var int
+   */
   public $type = null;
+  /**
+   * @var string
+   */
   public $state = null;
+  /**
+   * @var string
+   */
   public $workerid = null;
+  /**
+   * @var int
+   */
   public $start = null;
+  /**
+   * @var string
+   */
   public $runAs = null;
 
   public function __construct($vals=null) {
@@ -11849,6 +12696,9 @@ class ShowCompactResponseElement {
 class ShowCompactResponse {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\ShowCompactResponseElement[]
+   */
   public $compacts = null;
 
   public function __construct($vals=null) {
@@ -11949,9 +12799,21 @@ class ShowCompactResponse {
 class AddDynamicPartitions {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $txnid = null;
+  /**
+   * @var string
+   */
   public $dbname = null;
+  /**
+   * @var string
+   */
   public $tablename = null;
+  /**
+   * @var string[]
+   */
   public $partitionnames = null;
 
   public function __construct($vals=null) {
@@ -12107,7 +12969,13 @@ class AddDynamicPartitions {
 class NotificationEventRequest {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $lastEvent = null;
+  /**
+   * @var int
+   */
   public $maxEvents = null;
 
   public function __construct($vals=null) {
@@ -12199,11 +13067,29 @@ class NotificationEventRequest {
 class NotificationEvent {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $eventId = null;
+  /**
+   * @var int
+   */
   public $eventTime = null;
+  /**
+   * @var string
+   */
   public $eventType = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -12371,6 +13257,9 @@ class NotificationEvent {
 class NotificationEventResponse {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\NotificationEvent[]
+   */
   public $events = null;
 
   public function __construct($vals=null) {
@@ -12471,6 +13360,9 @@ class NotificationEventResponse {
 class CurrentNotificationEventId {
   static $_TSPEC;
 
+  /**
+   * @var int
+   */
   public $eventId = null;
 
   public function __construct($vals=null) {
@@ -12543,6 +13435,9 @@ class CurrentNotificationEventId {
 class InsertEventRequestData {
   static $_TSPEC;
 
+  /**
+   * @var string[]
+   */
   public $filesAdded = null;
 
   public function __construct($vals=null) {
@@ -12641,6 +13536,9 @@ class InsertEventRequestData {
 class FireEventRequestData {
   static $_TSPEC;
 
+  /**
+   * @var \metastore\InsertEventRequestData
+   */
   public $insertData = null;
 
   public function __construct($vals=null) {
@@ -12718,10 +13616,25 @@ class FireEventRequestData {
 class FireEventRequest {
   static $_TSPEC;
 
+  /**
+   * @var bool
+   */
   public $successful = null;
+  /**
+   * @var \metastore\FireEventRequestData
+   */
   public $data = null;
+  /**
+   * @var string
+   */
   public $dbName = null;
+  /**
+   * @var string
+   */
   public $tableName = null;
+  /**
+   * @var string[]
+   */
   public $partitionVals = null;
 
   public function __construct($vals=null) {
@@ -12951,6 +13864,9 @@ class FireEventResponse {
 class MetaException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13023,6 +13939,9 @@ class MetaException extends TException {
 class UnknownTableException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13095,6 +14014,9 @@ class UnknownTableException extends TException {
 class UnknownDBException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13167,6 +14089,9 @@ class UnknownDBException extends TException {
 class AlreadyExistsException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13239,6 +14164,9 @@ class AlreadyExistsException extends TException {
 class InvalidPartitionException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13311,6 +14239,9 @@ class InvalidPartitionException extends TException {
 class UnknownPartitionException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13383,6 +14314,9 @@ class UnknownPartitionException extends TException {
 class InvalidObjectException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13455,6 +14389,9 @@ class InvalidObjectException extends TException {
 class NoSuchObjectException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13527,6 +14464,9 @@ class NoSuchObjectException extends TException {
 class IndexAlreadyExistsException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13599,6 +14539,9 @@ class IndexAlreadyExistsException extends TException {
 class InvalidOperationException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13671,6 +14614,9 @@ class InvalidOperationException extends TException {
 class ConfigValSecurityException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13743,6 +14689,9 @@ class ConfigValSecurityException extends TException {
 class InvalidInputException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13815,6 +14764,9 @@ class InvalidInputException extends TException {
 class NoSuchTxnException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13887,6 +14839,9 @@ class NoSuchTxnException extends TException {
 class TxnAbortedException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -13959,6 +14914,9 @@ class TxnAbortedException extends TException {
 class TxnOpenException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -14031,6 +14989,9 @@ class TxnOpenException extends TException {
 class NoSuchLockException extends TException {
   static $_TSPEC;
 
+  /**
+   * @var string
+   */
   public $message = null;
 
   public function __construct($vals=null) {
@@ -14100,50 +15061,122 @@ class NoSuchLockException extends TException {
 
 }
 
-$GLOBALS['hive_metastore_CONSTANTS']['DDL_TIME'] = "transient_lastDdlTime";
+final class Constant extends \Thrift\Type\TConstant {
+  static protected $DDL_TIME;
+  static protected $HIVE_FILTER_FIELD_OWNER;
+  static protected $HIVE_FILTER_FIELD_PARAMS;
+  static protected $HIVE_FILTER_FIELD_LAST_ACCESS;
+  static protected $IS_ARCHIVED;
+  static protected $ORIGINAL_LOCATION;
+  static protected $IS_IMMUTABLE;
+  static protected $META_TABLE_COLUMNS;
+  static protected $META_TABLE_COLUMN_TYPES;
+  static protected $BUCKET_FIELD_NAME;
+  static protected $BUCKET_COUNT;
+  static protected $FIELD_TO_DIMENSION;
+  static protected $META_TABLE_NAME;
+  static protected $META_TABLE_DB;
+  static protected $META_TABLE_LOCATION;
+  static protected $META_TABLE_SERDE;
+  static protected $META_TABLE_PARTITION_COLUMNS;
+  static protected $META_TABLE_PARTITION_COLUMN_TYPES;
+  static protected $FILE_INPUT_FORMAT;
+  static protected $FILE_OUTPUT_FORMAT;
+  static protected $META_TABLE_STORAGE;
+  static protected $TABLE_IS_TRANSACTIONAL;
+  static protected $TABLE_NO_AUTO_COMPACT;
 
-$GLOBALS['hive_metastore_CONSTANTS']['HIVE_FILTER_FIELD_OWNER'] = "hive_filter_field_owner__";
+  static protected function init_DDL_TIME() {
+    return "transient_lastDdlTime";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['HIVE_FILTER_FIELD_PARAMS'] = "hive_filter_field_params__";
+  static protected function init_HIVE_FILTER_FIELD_OWNER() {
+    return "hive_filter_field_owner__";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['HIVE_FILTER_FIELD_LAST_ACCESS'] = "hive_filter_field_last_access__";
+  static protected function init_HIVE_FILTER_FIELD_PARAMS() {
+    return "hive_filter_field_params__";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['IS_ARCHIVED'] = "is_archived";
+  static protected function init_HIVE_FILTER_FIELD_LAST_ACCESS() {
+    return "hive_filter_field_last_access__";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['ORIGINAL_LOCATION'] = "original_location";
+  static protected function init_IS_ARCHIVED() {
+    return "is_archived";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['IS_IMMUTABLE'] = "immutable";
+  static protected function init_ORIGINAL_LOCATION() {
+    return "original_location";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_COLUMNS'] = "columns";
+  static protected function init_IS_IMMUTABLE() {
+    return "immutable";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_COLUMN_TYPES'] = "columns.types";
+  static protected function init_META_TABLE_COLUMNS() {
+    return "columns";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['BUCKET_FIELD_NAME'] = "bucket_field_name";
+  static protected function init_META_TABLE_COLUMN_TYPES() {
+    return "columns.types";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['BUCKET_COUNT'] = "bucket_count";
+  static protected function init_BUCKET_FIELD_NAME() {
+    return "bucket_field_name";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['FIELD_TO_DIMENSION'] = "field_to_dimension";
+  static protected function init_BUCKET_COUNT() {
+    return "bucket_count";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_NAME'] = "name";
+  static protected function init_FIELD_TO_DIMENSION() {
+    return "field_to_dimension";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_DB'] = "db";
+  static protected function init_META_TABLE_NAME() {
+    return "name";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_LOCATION'] = "location";
+  static protected function init_META_TABLE_DB() {
+    return "db";
+  }
+
+  static protected function init_META_TABLE_LOCATION() {
+    return "location";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_SERDE'] = "serde";
+  static protected function init_META_TABLE_SERDE() {
+    return "serde";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_PARTITION_COLUMNS'] = "partition_columns";
+  static protected function init_META_TABLE_PARTITION_COLUMNS() {
+    return "partition_columns";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_PARTITION_COLUMN_TYPES'] = "partition_columns.types";
+  static protected function init_META_TABLE_PARTITION_COLUMN_TYPES() {
+    return "partition_columns.types";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['FILE_INPUT_FORMAT'] = "file.inputformat";
+  static protected function init_FILE_INPUT_FORMAT() {
+    return "file.inputformat";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['FILE_OUTPUT_FORMAT'] = "file.outputformat";
+  static protected function init_FILE_OUTPUT_FORMAT() {
+    return "file.outputformat";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['META_TABLE_STORAGE'] = "storage_handler";
+  static protected function init_META_TABLE_STORAGE() {
+    return "storage_handler";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['TABLE_IS_TRANSACTIONAL'] = "transactional";
+  static protected function init_TABLE_IS_TRANSACTIONAL() {
+    return "transactional";
+  }
 
-$GLOBALS['hive_metastore_CONSTANTS']['TABLE_NO_AUTO_COMPACT'] = "no_auto_compaction";
+  static protected function init_TABLE_NO_AUTO_COMPACT() {
+    return "no_auto_compaction";
+  }
+}
 
 


[19/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/udf_example_add.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/udf_example_add.q.out b/ql/src/test/results/clientpositive/spark/udf_example_add.q.out
index 7916679..587c68b 100644
--- a/ql/src/test/results/clientpositive/spark/udf_example_add.q.out
+++ b/ql/src/test/results/clientpositive/spark/udf_example_add.q.out
@@ -34,14 +34,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: src
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: COMPLETE
           Select Operator
             expressions: 3 (type: int), 6 (type: int), 10 (type: int), 3.3000000000000003 (type: double), 6.6 (type: double), 11.0 (type: double), 10.4 (type: double)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6
-            Statistics: Num rows: 500 Data size: 22000 Basic stats: COMPLETE Column stats: COMPLETE
             Limit
               Number of rows: 1
-              Statistics: Num rows: 1 Data size: 44 Basic stats: COMPLETE Column stats: COMPLETE
               ListSink
 
 PREHOOK: query: SELECT example_add(1, 2),

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/udf_in_file.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/udf_in_file.q.out b/ql/src/test/results/clientpositive/spark/udf_in_file.q.out
index 5ba62b0..be0627c 100644
--- a/ql/src/test/results/clientpositive/spark/udf_in_file.q.out
+++ b/ql/src/test/results/clientpositive/spark/udf_in_file.q.out
@@ -57,14 +57,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: value_src
-          Statistics: Num rows: 1 Data size: 24 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: in_file(str_val, '../../data/files/test2.dat') (type: boolean), in_file(ch_val, '../../data/files/test2.dat') (type: boolean), in_file(vch_val, '../../data/files/test2.dat') (type: boolean), in_file(str_val_neg, '../../data/files/test2.dat') (type: boolean), in_file(ch_val_neg, '../../data/files/test2.dat') (type: boolean), in_file(vch_val_neg, '../../data/files/test2.dat') (type: boolean), in_file('303', '../../data/files/test2.dat') (type: boolean), in_file('304', '../../data/files/test2.dat') (type: boolean), in_file(null, '../../data/files/test2.dat') (type: boolean)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
-            Statistics: Num rows: 1 Data size: 24 Basic stats: COMPLETE Column stats: NONE
             Limit
               Number of rows: 1
-              Statistics: Num rows: 1 Data size: 24 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: SELECT in_file(str_val, "../../data/files/test2.dat"),

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/union_view.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/union_view.q.out b/ql/src/test/results/clientpositive/spark/union_view.q.out
index 31e0786..cce7710 100644
--- a/ql/src/test/results/clientpositive/spark/union_view.q.out
+++ b/ql/src/test/results/clientpositive/spark/union_view.q.out
@@ -54,14 +54,11 @@ STAGE PLANS:
         TableScan
           alias: src_union_1
           filterExpr: ((key = 86) and (ds = '1')) (type: boolean)
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (key = 86) (type: boolean)
-            Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: 86 (type: int), value (type: string), '1' (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 STAGE DEPENDENCIES:
@@ -75,14 +72,11 @@ STAGE PLANS:
         TableScan
           alias: src_union_2
           filterExpr: ((key = 86) and (ds = '2')) (type: boolean)
-          Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (key = 86) (type: boolean)
-            Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: 86 (type: int), value (type: string), '2' (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 STAGE DEPENDENCIES:
@@ -96,14 +90,11 @@ STAGE PLANS:
         TableScan
           alias: src_union_3
           filterExpr: ((key = 86) and (ds = '3')) (type: boolean)
-          Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (key = 86) (type: boolean)
-            Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: 86 (type: int), value (type: string), '3' (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 86	val_86	1

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vector_elt.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vector_elt.q.out b/ql/src/test/results/clientpositive/spark/vector_elt.q.out
index 49d1458..bb66867 100644
--- a/ql/src/test/results/clientpositive/spark/vector_elt.q.out
+++ b/ql/src/test/results/clientpositive/spark/vector_elt.q.out
@@ -16,17 +16,13 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (ctinyint > 0) (type: boolean)
-            Statistics: Num rows: 4096 Data size: 125745 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: ((UDFToInteger(ctinyint) % 2) + 1) (type: int), cstring1 (type: string), cint (type: int), elt(((UDFToInteger(ctinyint) % 2) + 1), cstring1, cint) (type: string)
               outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 4096 Data size: 125745 Basic stats: COMPLETE Column stats: NONE
               Limit
                 Number of rows: 10
-                Statistics: Num rows: 10 Data size: 300 Basic stats: COMPLETE Column stats: NONE
                 ListSink
 
 PREHOOK: query: SELECT (ctinyint % 2) + 1, cstring1, cint, elt((ctinyint % 2) + 1, cstring1, cint) 
@@ -87,14 +83,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: COMPLETE
           Select Operator
             expressions: 'defg' (type: string), 'cc' (type: string), 'abc' (type: string), '2' (type: string), '12345' (type: string), '123456789012' (type: string), '1.25' (type: string), '16.0' (type: string), null (type: string), null (type: string)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9
-            Statistics: Num rows: 12288 Data size: 8687616 Basic stats: COMPLETE Column stats: COMPLETE
             Limit
               Number of rows: 1
-              Statistics: Num rows: 1 Data size: 707 Basic stats: COMPLETE Column stats: COMPLETE
               ListSink
 
 PREHOOK: query: SELECT elt(2, 'abc', 'defg'),

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vector_string_concat.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vector_string_concat.q.out b/ql/src/test/results/clientpositive/spark/vector_string_concat.q.out
index b78aec9..5a2f9e4 100644
--- a/ql/src/test/results/clientpositive/spark/vector_string_concat.q.out
+++ b/ql/src/test/results/clientpositive/spark/vector_string_concat.q.out
@@ -117,14 +117,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: over1korc
-          Statistics: Num rows: 1049 Data size: 311170 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: s (type: string), concat(concat('      ', s), '      ') (type: string), concat(concat('|', rtrim(concat(concat('      ', s), '      '))), '|') (type: string)
             outputColumnNames: _col0, _col1, _col2
-            Statistics: Num rows: 1049 Data size: 311170 Basic stats: COMPLETE Column stats: NONE
             Limit
               Number of rows: 20
-              Statistics: Num rows: 20 Data size: 5920 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: SELECT s AS `string`,

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vectorization_decimal_date.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vectorization_decimal_date.q.out b/ql/src/test/results/clientpositive/spark/vectorization_decimal_date.q.out
index 19799b3..c20033c 100644
--- a/ql/src/test/results/clientpositive/spark/vectorization_decimal_date.q.out
+++ b/ql/src/test/results/clientpositive/spark/vectorization_decimal_date.q.out
@@ -22,17 +22,13 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: date_decimal_test
-          Statistics: Num rows: 12288 Data size: 1651260 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (cint is not null and cdouble is not null) (type: boolean)
-            Statistics: Num rows: 3072 Data size: 412815 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: cdate (type: date), cdecimal (type: decimal(20,10))
               outputColumnNames: _col0, _col1
-              Statistics: Num rows: 3072 Data size: 412815 Basic stats: COMPLETE Column stats: NONE
               Limit
                 Number of rows: 10
-                Statistics: Num rows: 10 Data size: 1340 Basic stats: COMPLETE Column stats: NONE
                 ListSink
 
 PREHOOK: query: SELECT cdate, cdecimal from date_decimal_test where cint IS NOT NULL AND cdouble IS NOT NULL LIMIT 10

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vectorization_div0.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vectorization_div0.q.out b/ql/src/test/results/clientpositive/spark/vectorization_div0.q.out
index 5887839..71f4b09 100644
--- a/ql/src/test/results/clientpositive/spark/vectorization_div0.q.out
+++ b/ql/src/test/results/clientpositive/spark/vectorization_div0.q.out
@@ -16,14 +16,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: (cdouble / 0.0) (type: double)
             outputColumnNames: _col0
-            Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
             Limit
               Number of rows: 100
-              Statistics: Num rows: 100 Data size: 3000 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select cdouble / 0.0 from alltypesorc limit 100

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vectorized_case.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vectorized_case.q.out b/ql/src/test/results/clientpositive/spark/vectorized_case.q.out
index 0e1e9d3..7f824f1 100644
--- a/ql/src/test/results/clientpositive/spark/vectorized_case.q.out
+++ b/ql/src/test/results/clientpositive/spark/vectorized_case.q.out
@@ -44,14 +44,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: ((csmallint = 418) or ((csmallint = 12205) or (csmallint = 10583))) (type: boolean)
-            Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: csmallint (type: smallint), CASE WHEN ((csmallint = 418)) THEN ('a') WHEN ((csmallint = 12205)) THEN ('b') ELSE ('c') END (type: string), CASE (csmallint) WHEN (418) THEN ('a') WHEN (12205) THEN ('b') ELSE ('c') END (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vectorized_math_funcs.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vectorized_math_funcs.q.out b/ql/src/test/results/clientpositive/spark/vectorized_math_funcs.q.out
index 470d9a9..444b9e0 100644
--- a/ql/src/test/results/clientpositive/spark/vectorized_math_funcs.q.out
+++ b/ql/src/test/results/clientpositive/spark/vectorized_math_funcs.q.out
@@ -116,14 +116,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (((cbigint % 500) = 0) and (sin(cfloat) >= -1.0)) (type: boolean)
-            Statistics: Num rows: 2048 Data size: 62872 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: cdouble (type: double), round(cdouble, 2) (type: double), floor(cdouble) (type: bigint), ceil(cdouble) (type: bigint), rand() (type: double), rand(98007) (type: double), exp(ln(cdouble)) (type: double), ln(cdouble) (type: double), ln(cfloat) (type: double), log10(cdouble) (type: double), log2(cdouble) (type: double), log2((cdouble - 15601.0)) (type: double), log2(cfloat) (type: double), log2(cbigint) (type: double), log2(cint) (type: double), log2(csmallint) (type: double), log2(ctinyint) (type: double), log(2.0, cdouble) (type: double), power(log2(cdouble), 2.0) (type: double), power(log2(cdouble), 2.0) (type: double), sqrt(cdouble) (type: double), sqrt(cbigint) (type: double), bin(cbigint) (type: string), hex(cdouble) (type: string), conv(cbigint, 10, 16) (type: string), abs(cdouble) (type: double), abs(ctinyint) (type: int), (cint pmod 3) (type: int), sin(cdouble) (type: double), asin(cdouble) (type: double), cos(cdouble) (type: double), acos(cdouble) (
 type: double), atan(cdouble) (type: double), degrees(cdouble) (type: double), radians(cdouble) (type: double), cdouble (type: double), cbigint (type: bigint), (- cdouble) (type: double), sign(cdouble) (type: double), sign(cbigint) (type: double), cos(((- sin(log(cdouble))) + 3.14159)) (type: double)
               outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12, _col13, _col14, _col15, _col16, _col17, _col18, _col19, _col20, _col21, _col22, _col23, _col24, _col25, _col26, _col27, _col28, _col29, _col30, _col31, _col32, _col33, _col34, _col35, _col36, _col37, _col38, _col39, _col40
-              Statistics: Num rows: 2048 Data size: 62872 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/vectorized_string_funcs.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/vectorized_string_funcs.q.out b/ql/src/test/results/clientpositive/spark/vectorized_string_funcs.q.out
index ef98ae9..0463d31 100644
--- a/ql/src/test/results/clientpositive/spark/vectorized_string_funcs.q.out
+++ b/ql/src/test/results/clientpositive/spark/vectorized_string_funcs.q.out
@@ -56,14 +56,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: alltypesorc
-          Statistics: Num rows: 12288 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: ((((cbigint % 237) = 0) and (length(substr(cstring1, 1, 2)) <= 2)) and (cstring1 like '%')) (type: boolean)
-            Statistics: Num rows: 1024 Data size: 31436 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: substr(cstring1, 1, 2) (type: string), substr(cstring1, 2) (type: string), lower(cstring1) (type: string), upper(cstring1) (type: string), upper(cstring1) (type: string), length(cstring1) (type: int), trim(cstring1) (type: string), ltrim(cstring1) (type: string), rtrim(cstring1) (type: string), concat(cstring1, cstring2) (type: string), concat('>', cstring1) (type: string), concat(cstring1, '<') (type: string), concat(substr(cstring1, 1, 2), substr(cstring2, 1, 2)) (type: string)
               outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12
-              Statistics: Num rows: 1024 Data size: 31436 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/complex_constants.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/complex_constants.cpp b/serde/src/gen/thrift/gen-cpp/complex_constants.cpp
index 768fc38..aa146c6 100644
--- a/serde/src/gen/thrift/gen-cpp/complex_constants.cpp
+++ b/serde/src/gen/thrift/gen-cpp/complex_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/complex_constants.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/complex_constants.h b/serde/src/gen/thrift/gen-cpp/complex_constants.h
index 6b115df..971cd2c 100644
--- a/serde/src/gen/thrift/gen-cpp/complex_constants.h
+++ b/serde/src/gen/thrift/gen-cpp/complex_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/complex_types.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/complex_types.cpp b/serde/src/gen/thrift/gen-cpp/complex_types.cpp
index 411e1b0..fb6fe25 100644
--- a/serde/src/gen/thrift/gen-cpp/complex_types.cpp
+++ b/serde/src/gen/thrift/gen-cpp/complex_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,9 +7,50 @@
 #include "complex_types.h"
 
 #include <algorithm>
+#include <ostream>
 
+#include <thrift/TToString.h>
 
 
+
+
+PropValueUnion::~PropValueUnion() throw() {
+}
+
+
+void PropValueUnion::__set_intValue(const int32_t val) {
+  this->intValue = val;
+__isset.intValue = true;
+}
+
+void PropValueUnion::__set_longValue(const int64_t val) {
+  this->longValue = val;
+__isset.longValue = true;
+}
+
+void PropValueUnion::__set_stringValue(const std::string& val) {
+  this->stringValue = val;
+__isset.stringValue = true;
+}
+
+void PropValueUnion::__set_doubleValue(const double val) {
+  this->doubleValue = val;
+__isset.doubleValue = true;
+}
+
+void PropValueUnion::__set_flag(const bool val) {
+  this->flag = val;
+__isset.flag = true;
+}
+
+void PropValueUnion::__set_lString(const std::vector<std::string> & val) {
+  this->lString = val;
+}
+
+void PropValueUnion::__set_unionMStringString(const std::map<std::string, std::string> & val) {
+  this->unionMStringString = val;
+}
+
 const char* PropValueUnion::ascii_fingerprint = "123CD9D82D5B5054B5054EFD63FC8590";
 const uint8_t PropValueUnion::binary_fingerprint[16] = {0x12,0x3C,0xD9,0xD8,0x2D,0x5B,0x50,0x54,0xB5,0x05,0x4E,0xFD,0x63,0xFC,0x85,0x90};
 
@@ -130,6 +171,7 @@ uint32_t PropValueUnion::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t PropValueUnion::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("PropValueUnion");
 
   if (this->__isset.intValue) {
@@ -184,6 +226,7 @@ uint32_t PropValueUnion::write(::apache::thrift::protocol::TProtocol* oprot) con
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -199,6 +242,58 @@ void swap(PropValueUnion &a, PropValueUnion &b) {
   swap(a.__isset, b.__isset);
 }
 
+PropValueUnion::PropValueUnion(const PropValueUnion& other14) {
+  intValue = other14.intValue;
+  longValue = other14.longValue;
+  stringValue = other14.stringValue;
+  doubleValue = other14.doubleValue;
+  flag = other14.flag;
+  lString = other14.lString;
+  unionMStringString = other14.unionMStringString;
+  __isset = other14.__isset;
+}
+PropValueUnion& PropValueUnion::operator=(const PropValueUnion& other15) {
+  intValue = other15.intValue;
+  longValue = other15.longValue;
+  stringValue = other15.stringValue;
+  doubleValue = other15.doubleValue;
+  flag = other15.flag;
+  lString = other15.lString;
+  unionMStringString = other15.unionMStringString;
+  __isset = other15.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const PropValueUnion& obj) {
+  using apache::thrift::to_string;
+  out << "PropValueUnion(";
+  out << "intValue="; (obj.__isset.intValue ? (out << to_string(obj.intValue)) : (out << "<null>"));
+  out << ", " << "longValue="; (obj.__isset.longValue ? (out << to_string(obj.longValue)) : (out << "<null>"));
+  out << ", " << "stringValue="; (obj.__isset.stringValue ? (out << to_string(obj.stringValue)) : (out << "<null>"));
+  out << ", " << "doubleValue="; (obj.__isset.doubleValue ? (out << to_string(obj.doubleValue)) : (out << "<null>"));
+  out << ", " << "flag="; (obj.__isset.flag ? (out << to_string(obj.flag)) : (out << "<null>"));
+  out << ", " << "lString=" << to_string(obj.lString);
+  out << ", " << "unionMStringString=" << to_string(obj.unionMStringString);
+  out << ")";
+  return out;
+}
+
+
+IntString::~IntString() throw() {
+}
+
+
+void IntString::__set_myint(const int32_t val) {
+  this->myint = val;
+}
+
+void IntString::__set_myString(const std::string& val) {
+  this->myString = val;
+}
+
+void IntString::__set_underscore_int(const int32_t val) {
+  this->underscore_int = val;
+}
+
 const char* IntString::ascii_fingerprint = "52C6DAB6CF51AF617111F6D3964C6503";
 const uint8_t IntString::binary_fingerprint[16] = {0x52,0xC6,0xDA,0xB6,0xCF,0x51,0xAF,0x61,0x71,0x11,0xF6,0xD3,0x96,0x4C,0x65,0x03};
 
@@ -260,6 +355,7 @@ uint32_t IntString::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t IntString::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("IntString");
 
   xfer += oprot->writeFieldBegin("myint", ::apache::thrift::protocol::T_I32, 1);
@@ -276,6 +372,7 @@ uint32_t IntString::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -287,6 +384,74 @@ void swap(IntString &a, IntString &b) {
   swap(a.__isset, b.__isset);
 }
 
+IntString::IntString(const IntString& other16) {
+  myint = other16.myint;
+  myString = other16.myString;
+  underscore_int = other16.underscore_int;
+  __isset = other16.__isset;
+}
+IntString& IntString::operator=(const IntString& other17) {
+  myint = other17.myint;
+  myString = other17.myString;
+  underscore_int = other17.underscore_int;
+  __isset = other17.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const IntString& obj) {
+  using apache::thrift::to_string;
+  out << "IntString(";
+  out << "myint=" << to_string(obj.myint);
+  out << ", " << "myString=" << to_string(obj.myString);
+  out << ", " << "underscore_int=" << to_string(obj.underscore_int);
+  out << ")";
+  return out;
+}
+
+
+Complex::~Complex() throw() {
+}
+
+
+void Complex::__set_aint(const int32_t val) {
+  this->aint = val;
+}
+
+void Complex::__set_aString(const std::string& val) {
+  this->aString = val;
+}
+
+void Complex::__set_lint(const std::vector<int32_t> & val) {
+  this->lint = val;
+}
+
+void Complex::__set_lString(const std::vector<std::string> & val) {
+  this->lString = val;
+}
+
+void Complex::__set_lintString(const std::vector<IntString> & val) {
+  this->lintString = val;
+}
+
+void Complex::__set_mStringString(const std::map<std::string, std::string> & val) {
+  this->mStringString = val;
+}
+
+void Complex::__set_attributes(const std::map<std::string, std::map<std::string, std::map<std::string, PropValueUnion> > > & val) {
+  this->attributes = val;
+}
+
+void Complex::__set_unionField1(const PropValueUnion& val) {
+  this->unionField1 = val;
+}
+
+void Complex::__set_unionField2(const PropValueUnion& val) {
+  this->unionField2 = val;
+}
+
+void Complex::__set_unionField3(const PropValueUnion& val) {
+  this->unionField3 = val;
+}
+
 const char* Complex::ascii_fingerprint = "FFA84FEA7037F5858F2BFEDA73AD679A";
 const uint8_t Complex::binary_fingerprint[16] = {0xFF,0xA8,0x4F,0xEA,0x70,0x37,0xF5,0x85,0x8F,0x2B,0xFE,0xDA,0x73,0xAD,0x67,0x9A};
 
@@ -330,14 +495,14 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->lint.clear();
-            uint32_t _size14;
-            ::apache::thrift::protocol::TType _etype17;
-            xfer += iprot->readListBegin(_etype17, _size14);
-            this->lint.resize(_size14);
-            uint32_t _i18;
-            for (_i18 = 0; _i18 < _size14; ++_i18)
+            uint32_t _size18;
+            ::apache::thrift::protocol::TType _etype21;
+            xfer += iprot->readListBegin(_etype21, _size18);
+            this->lint.resize(_size18);
+            uint32_t _i22;
+            for (_i22 = 0; _i22 < _size18; ++_i22)
             {
-              xfer += iprot->readI32(this->lint[_i18]);
+              xfer += iprot->readI32(this->lint[_i22]);
             }
             xfer += iprot->readListEnd();
           }
@@ -350,14 +515,14 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->lString.clear();
-            uint32_t _size19;
-            ::apache::thrift::protocol::TType _etype22;
-            xfer += iprot->readListBegin(_etype22, _size19);
-            this->lString.resize(_size19);
-            uint32_t _i23;
-            for (_i23 = 0; _i23 < _size19; ++_i23)
+            uint32_t _size23;
+            ::apache::thrift::protocol::TType _etype26;
+            xfer += iprot->readListBegin(_etype26, _size23);
+            this->lString.resize(_size23);
+            uint32_t _i27;
+            for (_i27 = 0; _i27 < _size23; ++_i27)
             {
-              xfer += iprot->readString(this->lString[_i23]);
+              xfer += iprot->readString(this->lString[_i27]);
             }
             xfer += iprot->readListEnd();
           }
@@ -370,14 +535,14 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->lintString.clear();
-            uint32_t _size24;
-            ::apache::thrift::protocol::TType _etype27;
-            xfer += iprot->readListBegin(_etype27, _size24);
-            this->lintString.resize(_size24);
-            uint32_t _i28;
-            for (_i28 = 0; _i28 < _size24; ++_i28)
+            uint32_t _size28;
+            ::apache::thrift::protocol::TType _etype31;
+            xfer += iprot->readListBegin(_etype31, _size28);
+            this->lintString.resize(_size28);
+            uint32_t _i32;
+            for (_i32 = 0; _i32 < _size28; ++_i32)
             {
-              xfer += this->lintString[_i28].read(iprot);
+              xfer += this->lintString[_i32].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -390,17 +555,17 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->mStringString.clear();
-            uint32_t _size29;
-            ::apache::thrift::protocol::TType _ktype30;
-            ::apache::thrift::protocol::TType _vtype31;
-            xfer += iprot->readMapBegin(_ktype30, _vtype31, _size29);
-            uint32_t _i33;
-            for (_i33 = 0; _i33 < _size29; ++_i33)
+            uint32_t _size33;
+            ::apache::thrift::protocol::TType _ktype34;
+            ::apache::thrift::protocol::TType _vtype35;
+            xfer += iprot->readMapBegin(_ktype34, _vtype35, _size33);
+            uint32_t _i37;
+            for (_i37 = 0; _i37 < _size33; ++_i37)
             {
-              std::string _key34;
-              xfer += iprot->readString(_key34);
-              std::string& _val35 = this->mStringString[_key34];
-              xfer += iprot->readString(_val35);
+              std::string _key38;
+              xfer += iprot->readString(_key38);
+              std::string& _val39 = this->mStringString[_key38];
+              xfer += iprot->readString(_val39);
             }
             xfer += iprot->readMapEnd();
           }
@@ -413,41 +578,41 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->attributes.clear();
-            uint32_t _size36;
-            ::apache::thrift::protocol::TType _ktype37;
-            ::apache::thrift::protocol::TType _vtype38;
-            xfer += iprot->readMapBegin(_ktype37, _vtype38, _size36);
-            uint32_t _i40;
-            for (_i40 = 0; _i40 < _size36; ++_i40)
+            uint32_t _size40;
+            ::apache::thrift::protocol::TType _ktype41;
+            ::apache::thrift::protocol::TType _vtype42;
+            xfer += iprot->readMapBegin(_ktype41, _vtype42, _size40);
+            uint32_t _i44;
+            for (_i44 = 0; _i44 < _size40; ++_i44)
             {
-              std::string _key41;
-              xfer += iprot->readString(_key41);
-              std::map<std::string, std::map<std::string, PropValueUnion> > & _val42 = this->attributes[_key41];
+              std::string _key45;
+              xfer += iprot->readString(_key45);
+              std::map<std::string, std::map<std::string, PropValueUnion> > & _val46 = this->attributes[_key45];
               {
-                _val42.clear();
-                uint32_t _size43;
-                ::apache::thrift::protocol::TType _ktype44;
-                ::apache::thrift::protocol::TType _vtype45;
-                xfer += iprot->readMapBegin(_ktype44, _vtype45, _size43);
-                uint32_t _i47;
-                for (_i47 = 0; _i47 < _size43; ++_i47)
+                _val46.clear();
+                uint32_t _size47;
+                ::apache::thrift::protocol::TType _ktype48;
+                ::apache::thrift::protocol::TType _vtype49;
+                xfer += iprot->readMapBegin(_ktype48, _vtype49, _size47);
+                uint32_t _i51;
+                for (_i51 = 0; _i51 < _size47; ++_i51)
                 {
-                  std::string _key48;
-                  xfer += iprot->readString(_key48);
-                  std::map<std::string, PropValueUnion> & _val49 = _val42[_key48];
+                  std::string _key52;
+                  xfer += iprot->readString(_key52);
+                  std::map<std::string, PropValueUnion> & _val53 = _val46[_key52];
                   {
-                    _val49.clear();
-                    uint32_t _size50;
-                    ::apache::thrift::protocol::TType _ktype51;
-                    ::apache::thrift::protocol::TType _vtype52;
-                    xfer += iprot->readMapBegin(_ktype51, _vtype52, _size50);
-                    uint32_t _i54;
-                    for (_i54 = 0; _i54 < _size50; ++_i54)
+                    _val53.clear();
+                    uint32_t _size54;
+                    ::apache::thrift::protocol::TType _ktype55;
+                    ::apache::thrift::protocol::TType _vtype56;
+                    xfer += iprot->readMapBegin(_ktype55, _vtype56, _size54);
+                    uint32_t _i58;
+                    for (_i58 = 0; _i58 < _size54; ++_i58)
                     {
-                      std::string _key55;
-                      xfer += iprot->readString(_key55);
-                      PropValueUnion& _val56 = _val49[_key55];
-                      xfer += _val56.read(iprot);
+                      std::string _key59;
+                      xfer += iprot->readString(_key59);
+                      PropValueUnion& _val60 = _val53[_key59];
+                      xfer += _val60.read(iprot);
                     }
                     xfer += iprot->readMapEnd();
                   }
@@ -500,6 +665,7 @@ uint32_t Complex::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Complex");
 
   xfer += oprot->writeFieldBegin("aint", ::apache::thrift::protocol::T_I32, 1);
@@ -513,10 +679,10 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("lint", ::apache::thrift::protocol::T_LIST, 3);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->lint.size()));
-    std::vector<int32_t> ::const_iterator _iter57;
-    for (_iter57 = this->lint.begin(); _iter57 != this->lint.end(); ++_iter57)
+    std::vector<int32_t> ::const_iterator _iter61;
+    for (_iter61 = this->lint.begin(); _iter61 != this->lint.end(); ++_iter61)
     {
-      xfer += oprot->writeI32((*_iter57));
+      xfer += oprot->writeI32((*_iter61));
     }
     xfer += oprot->writeListEnd();
   }
@@ -525,10 +691,10 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("lString", ::apache::thrift::protocol::T_LIST, 4);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->lString.size()));
-    std::vector<std::string> ::const_iterator _iter58;
-    for (_iter58 = this->lString.begin(); _iter58 != this->lString.end(); ++_iter58)
+    std::vector<std::string> ::const_iterator _iter62;
+    for (_iter62 = this->lString.begin(); _iter62 != this->lString.end(); ++_iter62)
     {
-      xfer += oprot->writeString((*_iter58));
+      xfer += oprot->writeString((*_iter62));
     }
     xfer += oprot->writeListEnd();
   }
@@ -537,10 +703,10 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("lintString", ::apache::thrift::protocol::T_LIST, 5);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->lintString.size()));
-    std::vector<IntString> ::const_iterator _iter59;
-    for (_iter59 = this->lintString.begin(); _iter59 != this->lintString.end(); ++_iter59)
+    std::vector<IntString> ::const_iterator _iter63;
+    for (_iter63 = this->lintString.begin(); _iter63 != this->lintString.end(); ++_iter63)
     {
-      xfer += (*_iter59).write(oprot);
+      xfer += (*_iter63).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -549,11 +715,11 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("mStringString", ::apache::thrift::protocol::T_MAP, 6);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->mStringString.size()));
-    std::map<std::string, std::string> ::const_iterator _iter60;
-    for (_iter60 = this->mStringString.begin(); _iter60 != this->mStringString.end(); ++_iter60)
+    std::map<std::string, std::string> ::const_iterator _iter64;
+    for (_iter64 = this->mStringString.begin(); _iter64 != this->mStringString.end(); ++_iter64)
     {
-      xfer += oprot->writeString(_iter60->first);
-      xfer += oprot->writeString(_iter60->second);
+      xfer += oprot->writeString(_iter64->first);
+      xfer += oprot->writeString(_iter64->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -562,23 +728,23 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("attributes", ::apache::thrift::protocol::T_MAP, 7);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_MAP, static_cast<uint32_t>(this->attributes.size()));
-    std::map<std::string, std::map<std::string, std::map<std::string, PropValueUnion> > > ::const_iterator _iter61;
-    for (_iter61 = this->attributes.begin(); _iter61 != this->attributes.end(); ++_iter61)
+    std::map<std::string, std::map<std::string, std::map<std::string, PropValueUnion> > > ::const_iterator _iter65;
+    for (_iter65 = this->attributes.begin(); _iter65 != this->attributes.end(); ++_iter65)
     {
-      xfer += oprot->writeString(_iter61->first);
+      xfer += oprot->writeString(_iter65->first);
       {
-        xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_MAP, static_cast<uint32_t>(_iter61->second.size()));
-        std::map<std::string, std::map<std::string, PropValueUnion> > ::const_iterator _iter62;
-        for (_iter62 = _iter61->second.begin(); _iter62 != _iter61->second.end(); ++_iter62)
+        xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_MAP, static_cast<uint32_t>(_iter65->second.size()));
+        std::map<std::string, std::map<std::string, PropValueUnion> > ::const_iterator _iter66;
+        for (_iter66 = _iter65->second.begin(); _iter66 != _iter65->second.end(); ++_iter66)
         {
-          xfer += oprot->writeString(_iter62->first);
+          xfer += oprot->writeString(_iter66->first);
           {
-            xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter62->second.size()));
-            std::map<std::string, PropValueUnion> ::const_iterator _iter63;
-            for (_iter63 = _iter62->second.begin(); _iter63 != _iter62->second.end(); ++_iter63)
+            xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter66->second.size()));
+            std::map<std::string, PropValueUnion> ::const_iterator _iter67;
+            for (_iter67 = _iter66->second.begin(); _iter67 != _iter66->second.end(); ++_iter67)
             {
-              xfer += oprot->writeString(_iter63->first);
-              xfer += _iter63->second.write(oprot);
+              xfer += oprot->writeString(_iter67->first);
+              xfer += _iter67->second.write(oprot);
             }
             xfer += oprot->writeMapEnd();
           }
@@ -604,6 +770,7 @@ uint32_t Complex::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -622,6 +789,63 @@ void swap(Complex &a, Complex &b) {
   swap(a.__isset, b.__isset);
 }
 
+Complex::Complex(const Complex& other68) {
+  aint = other68.aint;
+  aString = other68.aString;
+  lint = other68.lint;
+  lString = other68.lString;
+  lintString = other68.lintString;
+  mStringString = other68.mStringString;
+  attributes = other68.attributes;
+  unionField1 = other68.unionField1;
+  unionField2 = other68.unionField2;
+  unionField3 = other68.unionField3;
+  __isset = other68.__isset;
+}
+Complex& Complex::operator=(const Complex& other69) {
+  aint = other69.aint;
+  aString = other69.aString;
+  lint = other69.lint;
+  lString = other69.lString;
+  lintString = other69.lintString;
+  mStringString = other69.mStringString;
+  attributes = other69.attributes;
+  unionField1 = other69.unionField1;
+  unionField2 = other69.unionField2;
+  unionField3 = other69.unionField3;
+  __isset = other69.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Complex& obj) {
+  using apache::thrift::to_string;
+  out << "Complex(";
+  out << "aint=" << to_string(obj.aint);
+  out << ", " << "aString=" << to_string(obj.aString);
+  out << ", " << "lint=" << to_string(obj.lint);
+  out << ", " << "lString=" << to_string(obj.lString);
+  out << ", " << "lintString=" << to_string(obj.lintString);
+  out << ", " << "mStringString=" << to_string(obj.mStringString);
+  out << ", " << "attributes=" << to_string(obj.attributes);
+  out << ", " << "unionField1=" << to_string(obj.unionField1);
+  out << ", " << "unionField2=" << to_string(obj.unionField2);
+  out << ", " << "unionField3=" << to_string(obj.unionField3);
+  out << ")";
+  return out;
+}
+
+
+SetIntString::~SetIntString() throw() {
+}
+
+
+void SetIntString::__set_sIntString(const std::set<IntString> & val) {
+  this->sIntString = val;
+}
+
+void SetIntString::__set_aString(const std::string& val) {
+  this->aString = val;
+}
+
 const char* SetIntString::ascii_fingerprint = "842B41C940D05DFB16183142A90DFC54";
 const uint8_t SetIntString::binary_fingerprint[16] = {0x84,0x2B,0x41,0xC9,0x40,0xD0,0x5D,0xFB,0x16,0x18,0x31,0x42,0xA9,0x0D,0xFC,0x54};
 
@@ -649,15 +873,15 @@ uint32_t SetIntString::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_SET) {
           {
             this->sIntString.clear();
-            uint32_t _size64;
-            ::apache::thrift::protocol::TType _etype67;
-            xfer += iprot->readSetBegin(_etype67, _size64);
-            uint32_t _i68;
-            for (_i68 = 0; _i68 < _size64; ++_i68)
+            uint32_t _size70;
+            ::apache::thrift::protocol::TType _etype73;
+            xfer += iprot->readSetBegin(_etype73, _size70);
+            uint32_t _i74;
+            for (_i74 = 0; _i74 < _size70; ++_i74)
             {
-              IntString _elem69;
-              xfer += _elem69.read(iprot);
-              this->sIntString.insert(_elem69);
+              IntString _elem75;
+              xfer += _elem75.read(iprot);
+              this->sIntString.insert(_elem75);
             }
             xfer += iprot->readSetEnd();
           }
@@ -688,15 +912,16 @@ uint32_t SetIntString::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t SetIntString::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("SetIntString");
 
   xfer += oprot->writeFieldBegin("sIntString", ::apache::thrift::protocol::T_SET, 1);
   {
     xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->sIntString.size()));
-    std::set<IntString> ::const_iterator _iter70;
-    for (_iter70 = this->sIntString.begin(); _iter70 != this->sIntString.end(); ++_iter70)
+    std::set<IntString> ::const_iterator _iter76;
+    for (_iter76 = this->sIntString.begin(); _iter76 != this->sIntString.end(); ++_iter76)
     {
-      xfer += (*_iter70).write(oprot);
+      xfer += (*_iter76).write(oprot);
     }
     xfer += oprot->writeSetEnd();
   }
@@ -708,6 +933,7 @@ uint32_t SetIntString::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -718,4 +944,24 @@ void swap(SetIntString &a, SetIntString &b) {
   swap(a.__isset, b.__isset);
 }
 
+SetIntString::SetIntString(const SetIntString& other77) {
+  sIntString = other77.sIntString;
+  aString = other77.aString;
+  __isset = other77.__isset;
+}
+SetIntString& SetIntString::operator=(const SetIntString& other78) {
+  sIntString = other78.sIntString;
+  aString = other78.aString;
+  __isset = other78.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const SetIntString& obj) {
+  using apache::thrift::to_string;
+  out << "SetIntString(";
+  out << "sIntString=" << to_string(obj.sIntString);
+  out << ", " << "aString=" << to_string(obj.aString);
+  out << ")";
+  return out;
+}
+
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/complex_types.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/complex_types.h b/serde/src/gen/thrift/gen-cpp/complex_types.h
index 3f4c760..2637720 100644
--- a/serde/src/gen/thrift/gen-cpp/complex_types.h
+++ b/serde/src/gen/thrift/gen-cpp/complex_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,24 +7,35 @@
 #ifndef complex_TYPES_H
 #define complex_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
+
+
+
 
+class PropValueUnion;
 
+class IntString;
 
+class Complex;
+
+class SetIntString;
 
 typedef struct _PropValueUnion__isset {
   _PropValueUnion__isset() : intValue(false), longValue(false), stringValue(false), doubleValue(false), flag(false), lString(false), unionMStringString(false) {}
-  bool intValue;
-  bool longValue;
-  bool stringValue;
-  bool doubleValue;
-  bool flag;
-  bool lString;
-  bool unionMStringString;
+  bool intValue :1;
+  bool longValue :1;
+  bool stringValue :1;
+  bool doubleValue :1;
+  bool flag :1;
+  bool lString :1;
+  bool unionMStringString :1;
 } _PropValueUnion__isset;
 
 class PropValueUnion {
@@ -33,11 +44,12 @@ class PropValueUnion {
   static const char* ascii_fingerprint; // = "123CD9D82D5B5054B5054EFD63FC8590";
   static const uint8_t binary_fingerprint[16]; // = {0x12,0x3C,0xD9,0xD8,0x2D,0x5B,0x50,0x54,0xB5,0x05,0x4E,0xFD,0x63,0xFC,0x85,0x90};
 
+  PropValueUnion(const PropValueUnion&);
+  PropValueUnion& operator=(const PropValueUnion&);
   PropValueUnion() : intValue(0), longValue(0), stringValue(), doubleValue(0), flag(0) {
   }
 
-  virtual ~PropValueUnion() throw() {}
-
+  virtual ~PropValueUnion() throw();
   int32_t intValue;
   int64_t longValue;
   std::string stringValue;
@@ -48,38 +60,19 @@ class PropValueUnion {
 
   _PropValueUnion__isset __isset;
 
-  void __set_intValue(const int32_t val) {
-    intValue = val;
-    __isset.intValue = true;
-  }
+  void __set_intValue(const int32_t val);
 
-  void __set_longValue(const int64_t val) {
-    longValue = val;
-    __isset.longValue = true;
-  }
+  void __set_longValue(const int64_t val);
 
-  void __set_stringValue(const std::string& val) {
-    stringValue = val;
-    __isset.stringValue = true;
-  }
+  void __set_stringValue(const std::string& val);
 
-  void __set_doubleValue(const double val) {
-    doubleValue = val;
-    __isset.doubleValue = true;
-  }
+  void __set_doubleValue(const double val);
 
-  void __set_flag(const bool val) {
-    flag = val;
-    __isset.flag = true;
-  }
+  void __set_flag(const bool val);
 
-  void __set_lString(const std::vector<std::string> & val) {
-    lString = val;
-  }
+  void __set_lString(const std::vector<std::string> & val);
 
-  void __set_unionMStringString(const std::map<std::string, std::string> & val) {
-    unionMStringString = val;
-  }
+  void __set_unionMStringString(const std::map<std::string, std::string> & val);
 
   bool operator == (const PropValueUnion & rhs) const
   {
@@ -118,15 +111,16 @@ class PropValueUnion {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PropValueUnion& obj);
 };
 
 void swap(PropValueUnion &a, PropValueUnion &b);
 
 typedef struct _IntString__isset {
   _IntString__isset() : myint(false), myString(false), underscore_int(false) {}
-  bool myint;
-  bool myString;
-  bool underscore_int;
+  bool myint :1;
+  bool myString :1;
+  bool underscore_int :1;
 } _IntString__isset;
 
 class IntString {
@@ -135,28 +129,23 @@ class IntString {
   static const char* ascii_fingerprint; // = "52C6DAB6CF51AF617111F6D3964C6503";
   static const uint8_t binary_fingerprint[16]; // = {0x52,0xC6,0xDA,0xB6,0xCF,0x51,0xAF,0x61,0x71,0x11,0xF6,0xD3,0x96,0x4C,0x65,0x03};
 
+  IntString(const IntString&);
+  IntString& operator=(const IntString&);
   IntString() : myint(0), myString(), underscore_int(0) {
   }
 
-  virtual ~IntString() throw() {}
-
+  virtual ~IntString() throw();
   int32_t myint;
   std::string myString;
   int32_t underscore_int;
 
   _IntString__isset __isset;
 
-  void __set_myint(const int32_t val) {
-    myint = val;
-  }
+  void __set_myint(const int32_t val);
 
-  void __set_myString(const std::string& val) {
-    myString = val;
-  }
+  void __set_myString(const std::string& val);
 
-  void __set_underscore_int(const int32_t val) {
-    underscore_int = val;
-  }
+  void __set_underscore_int(const int32_t val);
 
   bool operator == (const IntString & rhs) const
   {
@@ -177,22 +166,23 @@ class IntString {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const IntString& obj);
 };
 
 void swap(IntString &a, IntString &b);
 
 typedef struct _Complex__isset {
   _Complex__isset() : aint(false), aString(false), lint(false), lString(false), lintString(false), mStringString(false), attributes(false), unionField1(false), unionField2(false), unionField3(false) {}
-  bool aint;
-  bool aString;
-  bool lint;
-  bool lString;
-  bool lintString;
-  bool mStringString;
-  bool attributes;
-  bool unionField1;
-  bool unionField2;
-  bool unionField3;
+  bool aint :1;
+  bool aString :1;
+  bool lint :1;
+  bool lString :1;
+  bool lintString :1;
+  bool mStringString :1;
+  bool attributes :1;
+  bool unionField1 :1;
+  bool unionField2 :1;
+  bool unionField3 :1;
 } _Complex__isset;
 
 class Complex {
@@ -201,11 +191,12 @@ class Complex {
   static const char* ascii_fingerprint; // = "FFA84FEA7037F5858F2BFEDA73AD679A";
   static const uint8_t binary_fingerprint[16]; // = {0xFF,0xA8,0x4F,0xEA,0x70,0x37,0xF5,0x85,0x8F,0x2B,0xFE,0xDA,0x73,0xAD,0x67,0x9A};
 
+  Complex(const Complex&);
+  Complex& operator=(const Complex&);
   Complex() : aint(0), aString() {
   }
 
-  virtual ~Complex() throw() {}
-
+  virtual ~Complex() throw();
   int32_t aint;
   std::string aString;
   std::vector<int32_t>  lint;
@@ -219,45 +210,25 @@ class Complex {
 
   _Complex__isset __isset;
 
-  void __set_aint(const int32_t val) {
-    aint = val;
-  }
+  void __set_aint(const int32_t val);
 
-  void __set_aString(const std::string& val) {
-    aString = val;
-  }
+  void __set_aString(const std::string& val);
 
-  void __set_lint(const std::vector<int32_t> & val) {
-    lint = val;
-  }
+  void __set_lint(const std::vector<int32_t> & val);
 
-  void __set_lString(const std::vector<std::string> & val) {
-    lString = val;
-  }
+  void __set_lString(const std::vector<std::string> & val);
 
-  void __set_lintString(const std::vector<IntString> & val) {
-    lintString = val;
-  }
+  void __set_lintString(const std::vector<IntString> & val);
 
-  void __set_mStringString(const std::map<std::string, std::string> & val) {
-    mStringString = val;
-  }
+  void __set_mStringString(const std::map<std::string, std::string> & val);
 
-  void __set_attributes(const std::map<std::string, std::map<std::string, std::map<std::string, PropValueUnion> > > & val) {
-    attributes = val;
-  }
+  void __set_attributes(const std::map<std::string, std::map<std::string, std::map<std::string, PropValueUnion> > > & val);
 
-  void __set_unionField1(const PropValueUnion& val) {
-    unionField1 = val;
-  }
+  void __set_unionField1(const PropValueUnion& val);
 
-  void __set_unionField2(const PropValueUnion& val) {
-    unionField2 = val;
-  }
+  void __set_unionField2(const PropValueUnion& val);
 
-  void __set_unionField3(const PropValueUnion& val) {
-    unionField3 = val;
-  }
+  void __set_unionField3(const PropValueUnion& val);
 
   bool operator == (const Complex & rhs) const
   {
@@ -292,14 +263,15 @@ class Complex {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Complex& obj);
 };
 
 void swap(Complex &a, Complex &b);
 
 typedef struct _SetIntString__isset {
   _SetIntString__isset() : sIntString(false), aString(false) {}
-  bool sIntString;
-  bool aString;
+  bool sIntString :1;
+  bool aString :1;
 } _SetIntString__isset;
 
 class SetIntString {
@@ -308,23 +280,20 @@ class SetIntString {
   static const char* ascii_fingerprint; // = "842B41C940D05DFB16183142A90DFC54";
   static const uint8_t binary_fingerprint[16]; // = {0x84,0x2B,0x41,0xC9,0x40,0xD0,0x5D,0xFB,0x16,0x18,0x31,0x42,0xA9,0x0D,0xFC,0x54};
 
+  SetIntString(const SetIntString&);
+  SetIntString& operator=(const SetIntString&);
   SetIntString() : aString() {
   }
 
-  virtual ~SetIntString() throw() {}
-
+  virtual ~SetIntString() throw();
   std::set<IntString>  sIntString;
   std::string aString;
 
   _SetIntString__isset __isset;
 
-  void __set_sIntString(const std::set<IntString> & val) {
-    sIntString = val;
-  }
+  void __set_sIntString(const std::set<IntString> & val);
 
-  void __set_aString(const std::string& val) {
-    aString = val;
-  }
+  void __set_aString(const std::string& val);
 
   bool operator == (const SetIntString & rhs) const
   {
@@ -343,6 +312,7 @@ class SetIntString {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const SetIntString& obj);
 };
 
 void swap(SetIntString &a, SetIntString &b);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/megastruct_constants.cpp
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/megastruct_constants.cpp b/serde/src/gen/thrift/gen-cpp/megastruct_constants.cpp
index 4bd82a1..9a18a48 100644
--- a/serde/src/gen/thrift/gen-cpp/megastruct_constants.cpp
+++ b/serde/src/gen/thrift/gen-cpp/megastruct_constants.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-cpp/megastruct_constants.h
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-cpp/megastruct_constants.h b/serde/src/gen/thrift/gen-cpp/megastruct_constants.h
index 9897f8f..1b0558f 100644
--- a/serde/src/gen/thrift/gen-cpp/megastruct_constants.h
+++ b/serde/src/gen/thrift/gen-cpp/megastruct_constants.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[13/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-cpp/TCLIService_types.cpp
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-cpp/TCLIService_types.cpp b/service/src/gen/thrift/gen-cpp/TCLIService_types.cpp
index 86eeea3..742cfdc 100644
--- a/service/src/gen/thrift/gen-cpp/TCLIService_types.cpp
+++ b/service/src/gen/thrift/gen-cpp/TCLIService_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "TCLIService_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 namespace apache { namespace hive { namespace service { namespace cli { namespace thrift {
 
@@ -262,6 +265,21 @@ const char* _kTFetchOrientationNames[] = {
 };
 const std::map<int, const char*> _TFetchOrientation_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(6, _kTFetchOrientationValues, _kTFetchOrientationNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
+
+TTypeQualifierValue::~TTypeQualifierValue() throw() {
+}
+
+
+void TTypeQualifierValue::__set_i32Value(const int32_t val) {
+  this->i32Value = val;
+__isset.i32Value = true;
+}
+
+void TTypeQualifierValue::__set_stringValue(const std::string& val) {
+  this->stringValue = val;
+__isset.stringValue = true;
+}
+
 const char* TTypeQualifierValue::ascii_fingerprint = "A7801670116150C65ACA43E6F679BA79";
 const uint8_t TTypeQualifierValue::binary_fingerprint[16] = {0xA7,0x80,0x16,0x70,0x11,0x61,0x50,0xC6,0x5A,0xCA,0x43,0xE6,0xF6,0x79,0xBA,0x79};
 
@@ -315,6 +333,7 @@ uint32_t TTypeQualifierValue::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t TTypeQualifierValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TTypeQualifierValue");
 
   if (this->__isset.i32Value) {
@@ -329,6 +348,7 @@ uint32_t TTypeQualifierValue::write(::apache::thrift::protocol::TProtocol* oprot
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -339,6 +359,35 @@ void swap(TTypeQualifierValue &a, TTypeQualifierValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TTypeQualifierValue::TTypeQualifierValue(const TTypeQualifierValue& other0) {
+  i32Value = other0.i32Value;
+  stringValue = other0.stringValue;
+  __isset = other0.__isset;
+}
+TTypeQualifierValue& TTypeQualifierValue::operator=(const TTypeQualifierValue& other1) {
+  i32Value = other1.i32Value;
+  stringValue = other1.stringValue;
+  __isset = other1.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TTypeQualifierValue& obj) {
+  using apache::thrift::to_string;
+  out << "TTypeQualifierValue(";
+  out << "i32Value="; (obj.__isset.i32Value ? (out << to_string(obj.i32Value)) : (out << "<null>"));
+  out << ", " << "stringValue="; (obj.__isset.stringValue ? (out << to_string(obj.stringValue)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TTypeQualifiers::~TTypeQualifiers() throw() {
+}
+
+
+void TTypeQualifiers::__set_qualifiers(const std::map<std::string, TTypeQualifierValue> & val) {
+  this->qualifiers = val;
+}
+
 const char* TTypeQualifiers::ascii_fingerprint = "6C72981CFA989214285648FA8C196C47";
 const uint8_t TTypeQualifiers::binary_fingerprint[16] = {0x6C,0x72,0x98,0x1C,0xFA,0x98,0x92,0x14,0x28,0x56,0x48,0xFA,0x8C,0x19,0x6C,0x47};
 
@@ -367,17 +416,17 @@ uint32_t TTypeQualifiers::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->qualifiers.clear();
-            uint32_t _size0;
-            ::apache::thrift::protocol::TType _ktype1;
-            ::apache::thrift::protocol::TType _vtype2;
-            xfer += iprot->readMapBegin(_ktype1, _vtype2, _size0);
-            uint32_t _i4;
-            for (_i4 = 0; _i4 < _size0; ++_i4)
+            uint32_t _size2;
+            ::apache::thrift::protocol::TType _ktype3;
+            ::apache::thrift::protocol::TType _vtype4;
+            xfer += iprot->readMapBegin(_ktype3, _vtype4, _size2);
+            uint32_t _i6;
+            for (_i6 = 0; _i6 < _size2; ++_i6)
             {
-              std::string _key5;
-              xfer += iprot->readString(_key5);
-              TTypeQualifierValue& _val6 = this->qualifiers[_key5];
-              xfer += _val6.read(iprot);
+              std::string _key7;
+              xfer += iprot->readString(_key7);
+              TTypeQualifierValue& _val8 = this->qualifiers[_key7];
+              xfer += _val8.read(iprot);
             }
             xfer += iprot->readMapEnd();
           }
@@ -402,16 +451,17 @@ uint32_t TTypeQualifiers::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TTypeQualifiers::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TTypeQualifiers");
 
   xfer += oprot->writeFieldBegin("qualifiers", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->qualifiers.size()));
-    std::map<std::string, TTypeQualifierValue> ::const_iterator _iter7;
-    for (_iter7 = this->qualifiers.begin(); _iter7 != this->qualifiers.end(); ++_iter7)
+    std::map<std::string, TTypeQualifierValue> ::const_iterator _iter9;
+    for (_iter9 = this->qualifiers.begin(); _iter9 != this->qualifiers.end(); ++_iter9)
     {
-      xfer += oprot->writeString(_iter7->first);
-      xfer += _iter7->second.write(oprot);
+      xfer += oprot->writeString(_iter9->first);
+      xfer += _iter9->second.write(oprot);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -419,6 +469,7 @@ uint32_t TTypeQualifiers::write(::apache::thrift::protocol::TProtocol* oprot) co
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -427,6 +478,35 @@ void swap(TTypeQualifiers &a, TTypeQualifiers &b) {
   swap(a.qualifiers, b.qualifiers);
 }
 
+TTypeQualifiers::TTypeQualifiers(const TTypeQualifiers& other10) {
+  qualifiers = other10.qualifiers;
+}
+TTypeQualifiers& TTypeQualifiers::operator=(const TTypeQualifiers& other11) {
+  qualifiers = other11.qualifiers;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TTypeQualifiers& obj) {
+  using apache::thrift::to_string;
+  out << "TTypeQualifiers(";
+  out << "qualifiers=" << to_string(obj.qualifiers);
+  out << ")";
+  return out;
+}
+
+
+TPrimitiveTypeEntry::~TPrimitiveTypeEntry() throw() {
+}
+
+
+void TPrimitiveTypeEntry::__set_type(const TTypeId::type val) {
+  this->type = val;
+}
+
+void TPrimitiveTypeEntry::__set_typeQualifiers(const TTypeQualifiers& val) {
+  this->typeQualifiers = val;
+__isset.typeQualifiers = true;
+}
+
 const char* TPrimitiveTypeEntry::ascii_fingerprint = "755674F6A5C8EB47868686AE386FBC1C";
 const uint8_t TPrimitiveTypeEntry::binary_fingerprint[16] = {0x75,0x56,0x74,0xF6,0xA5,0xC8,0xEB,0x47,0x86,0x86,0x86,0xAE,0x38,0x6F,0xBC,0x1C};
 
@@ -453,9 +533,9 @@ uint32_t TPrimitiveTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot)
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast8;
-          xfer += iprot->readI32(ecast8);
-          this->type = (TTypeId::type)ecast8;
+          int32_t ecast12;
+          xfer += iprot->readI32(ecast12);
+          this->type = (TTypeId::type)ecast12;
           isset_type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -485,6 +565,7 @@ uint32_t TPrimitiveTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t TPrimitiveTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TPrimitiveTypeEntry");
 
   xfer += oprot->writeFieldBegin("type", ::apache::thrift::protocol::T_I32, 1);
@@ -498,6 +579,7 @@ uint32_t TPrimitiveTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -508,6 +590,35 @@ void swap(TPrimitiveTypeEntry &a, TPrimitiveTypeEntry &b) {
   swap(a.__isset, b.__isset);
 }
 
+TPrimitiveTypeEntry::TPrimitiveTypeEntry(const TPrimitiveTypeEntry& other13) {
+  type = other13.type;
+  typeQualifiers = other13.typeQualifiers;
+  __isset = other13.__isset;
+}
+TPrimitiveTypeEntry& TPrimitiveTypeEntry::operator=(const TPrimitiveTypeEntry& other14) {
+  type = other14.type;
+  typeQualifiers = other14.typeQualifiers;
+  __isset = other14.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TPrimitiveTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TPrimitiveTypeEntry(";
+  out << "type=" << to_string(obj.type);
+  out << ", " << "typeQualifiers="; (obj.__isset.typeQualifiers ? (out << to_string(obj.typeQualifiers)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TArrayTypeEntry::~TArrayTypeEntry() throw() {
+}
+
+
+void TArrayTypeEntry::__set_objectTypePtr(const TTypeEntryPtr val) {
+  this->objectTypePtr = val;
+}
+
 const char* TArrayTypeEntry::ascii_fingerprint = "E86CACEB22240450EDCBEFC3A83970E4";
 const uint8_t TArrayTypeEntry::binary_fingerprint[16] = {0xE8,0x6C,0xAC,0xEB,0x22,0x24,0x04,0x50,0xED,0xCB,0xEF,0xC3,0xA8,0x39,0x70,0xE4};
 
@@ -556,6 +667,7 @@ uint32_t TArrayTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TArrayTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TArrayTypeEntry");
 
   xfer += oprot->writeFieldBegin("objectTypePtr", ::apache::thrift::protocol::T_I32, 1);
@@ -564,6 +676,7 @@ uint32_t TArrayTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) co
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -572,6 +685,34 @@ void swap(TArrayTypeEntry &a, TArrayTypeEntry &b) {
   swap(a.objectTypePtr, b.objectTypePtr);
 }
 
+TArrayTypeEntry::TArrayTypeEntry(const TArrayTypeEntry& other15) {
+  objectTypePtr = other15.objectTypePtr;
+}
+TArrayTypeEntry& TArrayTypeEntry::operator=(const TArrayTypeEntry& other16) {
+  objectTypePtr = other16.objectTypePtr;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TArrayTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TArrayTypeEntry(";
+  out << "objectTypePtr=" << to_string(obj.objectTypePtr);
+  out << ")";
+  return out;
+}
+
+
+TMapTypeEntry::~TMapTypeEntry() throw() {
+}
+
+
+void TMapTypeEntry::__set_keyTypePtr(const TTypeEntryPtr val) {
+  this->keyTypePtr = val;
+}
+
+void TMapTypeEntry::__set_valueTypePtr(const TTypeEntryPtr val) {
+  this->valueTypePtr = val;
+}
+
 const char* TMapTypeEntry::ascii_fingerprint = "989D1F1AE8D148D5E2119FFEC4BBBEE3";
 const uint8_t TMapTypeEntry::binary_fingerprint[16] = {0x98,0x9D,0x1F,0x1A,0xE8,0xD1,0x48,0xD5,0xE2,0x11,0x9F,0xFE,0xC4,0xBB,0xBE,0xE3};
 
@@ -631,6 +772,7 @@ uint32_t TMapTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TMapTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TMapTypeEntry");
 
   xfer += oprot->writeFieldBegin("keyTypePtr", ::apache::thrift::protocol::T_I32, 1);
@@ -643,6 +785,7 @@ uint32_t TMapTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -652,6 +795,33 @@ void swap(TMapTypeEntry &a, TMapTypeEntry &b) {
   swap(a.valueTypePtr, b.valueTypePtr);
 }
 
+TMapTypeEntry::TMapTypeEntry(const TMapTypeEntry& other17) {
+  keyTypePtr = other17.keyTypePtr;
+  valueTypePtr = other17.valueTypePtr;
+}
+TMapTypeEntry& TMapTypeEntry::operator=(const TMapTypeEntry& other18) {
+  keyTypePtr = other18.keyTypePtr;
+  valueTypePtr = other18.valueTypePtr;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TMapTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TMapTypeEntry(";
+  out << "keyTypePtr=" << to_string(obj.keyTypePtr);
+  out << ", " << "valueTypePtr=" << to_string(obj.valueTypePtr);
+  out << ")";
+  return out;
+}
+
+
+TStructTypeEntry::~TStructTypeEntry() throw() {
+}
+
+
+void TStructTypeEntry::__set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val) {
+  this->nameToTypePtr = val;
+}
+
 const char* TStructTypeEntry::ascii_fingerprint = "91F548CA159B4AB4291F5741AC161402";
 const uint8_t TStructTypeEntry::binary_fingerprint[16] = {0x91,0xF5,0x48,0xCA,0x15,0x9B,0x4A,0xB4,0x29,0x1F,0x57,0x41,0xAC,0x16,0x14,0x02};
 
@@ -680,17 +850,17 @@ uint32_t TStructTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->nameToTypePtr.clear();
-            uint32_t _size9;
-            ::apache::thrift::protocol::TType _ktype10;
-            ::apache::thrift::protocol::TType _vtype11;
-            xfer += iprot->readMapBegin(_ktype10, _vtype11, _size9);
-            uint32_t _i13;
-            for (_i13 = 0; _i13 < _size9; ++_i13)
+            uint32_t _size19;
+            ::apache::thrift::protocol::TType _ktype20;
+            ::apache::thrift::protocol::TType _vtype21;
+            xfer += iprot->readMapBegin(_ktype20, _vtype21, _size19);
+            uint32_t _i23;
+            for (_i23 = 0; _i23 < _size19; ++_i23)
             {
-              std::string _key14;
-              xfer += iprot->readString(_key14);
-              TTypeEntryPtr& _val15 = this->nameToTypePtr[_key14];
-              xfer += iprot->readI32(_val15);
+              std::string _key24;
+              xfer += iprot->readString(_key24);
+              TTypeEntryPtr& _val25 = this->nameToTypePtr[_key24];
+              xfer += iprot->readI32(_val25);
             }
             xfer += iprot->readMapEnd();
           }
@@ -715,16 +885,17 @@ uint32_t TStructTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TStructTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TStructTypeEntry");
 
   xfer += oprot->writeFieldBegin("nameToTypePtr", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->nameToTypePtr.size()));
-    std::map<std::string, TTypeEntryPtr> ::const_iterator _iter16;
-    for (_iter16 = this->nameToTypePtr.begin(); _iter16 != this->nameToTypePtr.end(); ++_iter16)
+    std::map<std::string, TTypeEntryPtr> ::const_iterator _iter26;
+    for (_iter26 = this->nameToTypePtr.begin(); _iter26 != this->nameToTypePtr.end(); ++_iter26)
     {
-      xfer += oprot->writeString(_iter16->first);
-      xfer += oprot->writeI32(_iter16->second);
+      xfer += oprot->writeString(_iter26->first);
+      xfer += oprot->writeI32(_iter26->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -732,6 +903,7 @@ uint32_t TStructTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) c
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -740,6 +912,30 @@ void swap(TStructTypeEntry &a, TStructTypeEntry &b) {
   swap(a.nameToTypePtr, b.nameToTypePtr);
 }
 
+TStructTypeEntry::TStructTypeEntry(const TStructTypeEntry& other27) {
+  nameToTypePtr = other27.nameToTypePtr;
+}
+TStructTypeEntry& TStructTypeEntry::operator=(const TStructTypeEntry& other28) {
+  nameToTypePtr = other28.nameToTypePtr;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TStructTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TStructTypeEntry(";
+  out << "nameToTypePtr=" << to_string(obj.nameToTypePtr);
+  out << ")";
+  return out;
+}
+
+
+TUnionTypeEntry::~TUnionTypeEntry() throw() {
+}
+
+
+void TUnionTypeEntry::__set_nameToTypePtr(const std::map<std::string, TTypeEntryPtr> & val) {
+  this->nameToTypePtr = val;
+}
+
 const char* TUnionTypeEntry::ascii_fingerprint = "91F548CA159B4AB4291F5741AC161402";
 const uint8_t TUnionTypeEntry::binary_fingerprint[16] = {0x91,0xF5,0x48,0xCA,0x15,0x9B,0x4A,0xB4,0x29,0x1F,0x57,0x41,0xAC,0x16,0x14,0x02};
 
@@ -768,17 +964,17 @@ uint32_t TUnionTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->nameToTypePtr.clear();
-            uint32_t _size17;
-            ::apache::thrift::protocol::TType _ktype18;
-            ::apache::thrift::protocol::TType _vtype19;
-            xfer += iprot->readMapBegin(_ktype18, _vtype19, _size17);
-            uint32_t _i21;
-            for (_i21 = 0; _i21 < _size17; ++_i21)
+            uint32_t _size29;
+            ::apache::thrift::protocol::TType _ktype30;
+            ::apache::thrift::protocol::TType _vtype31;
+            xfer += iprot->readMapBegin(_ktype30, _vtype31, _size29);
+            uint32_t _i33;
+            for (_i33 = 0; _i33 < _size29; ++_i33)
             {
-              std::string _key22;
-              xfer += iprot->readString(_key22);
-              TTypeEntryPtr& _val23 = this->nameToTypePtr[_key22];
-              xfer += iprot->readI32(_val23);
+              std::string _key34;
+              xfer += iprot->readString(_key34);
+              TTypeEntryPtr& _val35 = this->nameToTypePtr[_key34];
+              xfer += iprot->readI32(_val35);
             }
             xfer += iprot->readMapEnd();
           }
@@ -803,16 +999,17 @@ uint32_t TUnionTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TUnionTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TUnionTypeEntry");
 
   xfer += oprot->writeFieldBegin("nameToTypePtr", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->nameToTypePtr.size()));
-    std::map<std::string, TTypeEntryPtr> ::const_iterator _iter24;
-    for (_iter24 = this->nameToTypePtr.begin(); _iter24 != this->nameToTypePtr.end(); ++_iter24)
+    std::map<std::string, TTypeEntryPtr> ::const_iterator _iter36;
+    for (_iter36 = this->nameToTypePtr.begin(); _iter36 != this->nameToTypePtr.end(); ++_iter36)
     {
-      xfer += oprot->writeString(_iter24->first);
-      xfer += oprot->writeI32(_iter24->second);
+      xfer += oprot->writeString(_iter36->first);
+      xfer += oprot->writeI32(_iter36->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -820,6 +1017,7 @@ uint32_t TUnionTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) co
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -828,6 +1026,30 @@ void swap(TUnionTypeEntry &a, TUnionTypeEntry &b) {
   swap(a.nameToTypePtr, b.nameToTypePtr);
 }
 
+TUnionTypeEntry::TUnionTypeEntry(const TUnionTypeEntry& other37) {
+  nameToTypePtr = other37.nameToTypePtr;
+}
+TUnionTypeEntry& TUnionTypeEntry::operator=(const TUnionTypeEntry& other38) {
+  nameToTypePtr = other38.nameToTypePtr;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TUnionTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TUnionTypeEntry(";
+  out << "nameToTypePtr=" << to_string(obj.nameToTypePtr);
+  out << ")";
+  return out;
+}
+
+
+TUserDefinedTypeEntry::~TUserDefinedTypeEntry() throw() {
+}
+
+
+void TUserDefinedTypeEntry::__set_typeClassName(const std::string& val) {
+  this->typeClassName = val;
+}
+
 const char* TUserDefinedTypeEntry::ascii_fingerprint = "EFB929595D312AC8F305D5A794CFEDA1";
 const uint8_t TUserDefinedTypeEntry::binary_fingerprint[16] = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
@@ -876,6 +1098,7 @@ uint32_t TUserDefinedTypeEntry::read(::apache::thrift::protocol::TProtocol* ipro
 
 uint32_t TUserDefinedTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TUserDefinedTypeEntry");
 
   xfer += oprot->writeFieldBegin("typeClassName", ::apache::thrift::protocol::T_STRING, 1);
@@ -884,6 +1107,7 @@ uint32_t TUserDefinedTypeEntry::write(::apache::thrift::protocol::TProtocol* opr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -892,6 +1116,50 @@ void swap(TUserDefinedTypeEntry &a, TUserDefinedTypeEntry &b) {
   swap(a.typeClassName, b.typeClassName);
 }
 
+TUserDefinedTypeEntry::TUserDefinedTypeEntry(const TUserDefinedTypeEntry& other39) {
+  typeClassName = other39.typeClassName;
+}
+TUserDefinedTypeEntry& TUserDefinedTypeEntry::operator=(const TUserDefinedTypeEntry& other40) {
+  typeClassName = other40.typeClassName;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TUserDefinedTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TUserDefinedTypeEntry(";
+  out << "typeClassName=" << to_string(obj.typeClassName);
+  out << ")";
+  return out;
+}
+
+
+TTypeEntry::~TTypeEntry() throw() {
+}
+
+
+void TTypeEntry::__set_primitiveEntry(const TPrimitiveTypeEntry& val) {
+  this->primitiveEntry = val;
+}
+
+void TTypeEntry::__set_arrayEntry(const TArrayTypeEntry& val) {
+  this->arrayEntry = val;
+}
+
+void TTypeEntry::__set_mapEntry(const TMapTypeEntry& val) {
+  this->mapEntry = val;
+}
+
+void TTypeEntry::__set_structEntry(const TStructTypeEntry& val) {
+  this->structEntry = val;
+}
+
+void TTypeEntry::__set_unionEntry(const TUnionTypeEntry& val) {
+  this->unionEntry = val;
+}
+
+void TTypeEntry::__set_userDefinedTypeEntry(const TUserDefinedTypeEntry& val) {
+  this->userDefinedTypeEntry = val;
+}
+
 const char* TTypeEntry::ascii_fingerprint = "2FE56D9097E325DAA7E933738C6D325F";
 const uint8_t TTypeEntry::binary_fingerprint[16] = {0x2F,0xE5,0x6D,0x90,0x97,0xE3,0x25,0xDA,0xA7,0xE9,0x33,0x73,0x8C,0x6D,0x32,0x5F};
 
@@ -977,6 +1245,7 @@ uint32_t TTypeEntry::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TTypeEntry");
 
   xfer += oprot->writeFieldBegin("primitiveEntry", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1005,6 +1274,7 @@ uint32_t TTypeEntry::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1019,6 +1289,47 @@ void swap(TTypeEntry &a, TTypeEntry &b) {
   swap(a.__isset, b.__isset);
 }
 
+TTypeEntry::TTypeEntry(const TTypeEntry& other41) {
+  primitiveEntry = other41.primitiveEntry;
+  arrayEntry = other41.arrayEntry;
+  mapEntry = other41.mapEntry;
+  structEntry = other41.structEntry;
+  unionEntry = other41.unionEntry;
+  userDefinedTypeEntry = other41.userDefinedTypeEntry;
+  __isset = other41.__isset;
+}
+TTypeEntry& TTypeEntry::operator=(const TTypeEntry& other42) {
+  primitiveEntry = other42.primitiveEntry;
+  arrayEntry = other42.arrayEntry;
+  mapEntry = other42.mapEntry;
+  structEntry = other42.structEntry;
+  unionEntry = other42.unionEntry;
+  userDefinedTypeEntry = other42.userDefinedTypeEntry;
+  __isset = other42.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TTypeEntry& obj) {
+  using apache::thrift::to_string;
+  out << "TTypeEntry(";
+  out << "primitiveEntry=" << to_string(obj.primitiveEntry);
+  out << ", " << "arrayEntry=" << to_string(obj.arrayEntry);
+  out << ", " << "mapEntry=" << to_string(obj.mapEntry);
+  out << ", " << "structEntry=" << to_string(obj.structEntry);
+  out << ", " << "unionEntry=" << to_string(obj.unionEntry);
+  out << ", " << "userDefinedTypeEntry=" << to_string(obj.userDefinedTypeEntry);
+  out << ")";
+  return out;
+}
+
+
+TTypeDesc::~TTypeDesc() throw() {
+}
+
+
+void TTypeDesc::__set_types(const std::vector<TTypeEntry> & val) {
+  this->types = val;
+}
+
 const char* TTypeDesc::ascii_fingerprint = "90B3C5A0B73419A84E85E0E48C452AA5";
 const uint8_t TTypeDesc::binary_fingerprint[16] = {0x90,0xB3,0xC5,0xA0,0xB7,0x34,0x19,0xA8,0x4E,0x85,0xE0,0xE4,0x8C,0x45,0x2A,0xA5};
 
@@ -1047,14 +1358,14 @@ uint32_t TTypeDesc::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->types.clear();
-            uint32_t _size25;
-            ::apache::thrift::protocol::TType _etype28;
-            xfer += iprot->readListBegin(_etype28, _size25);
-            this->types.resize(_size25);
-            uint32_t _i29;
-            for (_i29 = 0; _i29 < _size25; ++_i29)
+            uint32_t _size43;
+            ::apache::thrift::protocol::TType _etype46;
+            xfer += iprot->readListBegin(_etype46, _size43);
+            this->types.resize(_size43);
+            uint32_t _i47;
+            for (_i47 = 0; _i47 < _size43; ++_i47)
             {
-              xfer += this->types[_i29].read(iprot);
+              xfer += this->types[_i47].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1079,15 +1390,16 @@ uint32_t TTypeDesc::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TTypeDesc::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TTypeDesc");
 
   xfer += oprot->writeFieldBegin("types", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->types.size()));
-    std::vector<TTypeEntry> ::const_iterator _iter30;
-    for (_iter30 = this->types.begin(); _iter30 != this->types.end(); ++_iter30)
+    std::vector<TTypeEntry> ::const_iterator _iter48;
+    for (_iter48 = this->types.begin(); _iter48 != this->types.end(); ++_iter48)
     {
-      xfer += (*_iter30).write(oprot);
+      xfer += (*_iter48).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1095,6 +1407,7 @@ uint32_t TTypeDesc::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1103,6 +1416,43 @@ void swap(TTypeDesc &a, TTypeDesc &b) {
   swap(a.types, b.types);
 }
 
+TTypeDesc::TTypeDesc(const TTypeDesc& other49) {
+  types = other49.types;
+}
+TTypeDesc& TTypeDesc::operator=(const TTypeDesc& other50) {
+  types = other50.types;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TTypeDesc& obj) {
+  using apache::thrift::to_string;
+  out << "TTypeDesc(";
+  out << "types=" << to_string(obj.types);
+  out << ")";
+  return out;
+}
+
+
+TColumnDesc::~TColumnDesc() throw() {
+}
+
+
+void TColumnDesc::__set_columnName(const std::string& val) {
+  this->columnName = val;
+}
+
+void TColumnDesc::__set_typeDesc(const TTypeDesc& val) {
+  this->typeDesc = val;
+}
+
+void TColumnDesc::__set_position(const int32_t val) {
+  this->position = val;
+}
+
+void TColumnDesc::__set_comment(const std::string& val) {
+  this->comment = val;
+__isset.comment = true;
+}
+
 const char* TColumnDesc::ascii_fingerprint = "EABED9009D5FCABFCA65612069F2A849";
 const uint8_t TColumnDesc::binary_fingerprint[16] = {0xEA,0xBE,0xD9,0x00,0x9D,0x5F,0xCA,0xBF,0xCA,0x65,0x61,0x20,0x69,0xF2,0xA8,0x49};
 
@@ -1181,6 +1531,7 @@ uint32_t TColumnDesc::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TColumnDesc::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TColumnDesc");
 
   xfer += oprot->writeFieldBegin("columnName", ::apache::thrift::protocol::T_STRING, 1);
@@ -1202,6 +1553,7 @@ uint32_t TColumnDesc::write(::apache::thrift::protocol::TProtocol* oprot) const
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1214,6 +1566,41 @@ void swap(TColumnDesc &a, TColumnDesc &b) {
   swap(a.__isset, b.__isset);
 }
 
+TColumnDesc::TColumnDesc(const TColumnDesc& other51) {
+  columnName = other51.columnName;
+  typeDesc = other51.typeDesc;
+  position = other51.position;
+  comment = other51.comment;
+  __isset = other51.__isset;
+}
+TColumnDesc& TColumnDesc::operator=(const TColumnDesc& other52) {
+  columnName = other52.columnName;
+  typeDesc = other52.typeDesc;
+  position = other52.position;
+  comment = other52.comment;
+  __isset = other52.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TColumnDesc& obj) {
+  using apache::thrift::to_string;
+  out << "TColumnDesc(";
+  out << "columnName=" << to_string(obj.columnName);
+  out << ", " << "typeDesc=" << to_string(obj.typeDesc);
+  out << ", " << "position=" << to_string(obj.position);
+  out << ", " << "comment="; (obj.__isset.comment ? (out << to_string(obj.comment)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TTableSchema::~TTableSchema() throw() {
+}
+
+
+void TTableSchema::__set_columns(const std::vector<TColumnDesc> & val) {
+  this->columns = val;
+}
+
 const char* TTableSchema::ascii_fingerprint = "7A1811E49313E5977107FC667B20E39D";
 const uint8_t TTableSchema::binary_fingerprint[16] = {0x7A,0x18,0x11,0xE4,0x93,0x13,0xE5,0x97,0x71,0x07,0xFC,0x66,0x7B,0x20,0xE3,0x9D};
 
@@ -1242,14 +1629,14 @@ uint32_t TTableSchema::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->columns.clear();
-            uint32_t _size31;
-            ::apache::thrift::protocol::TType _etype34;
-            xfer += iprot->readListBegin(_etype34, _size31);
-            this->columns.resize(_size31);
-            uint32_t _i35;
-            for (_i35 = 0; _i35 < _size31; ++_i35)
+            uint32_t _size53;
+            ::apache::thrift::protocol::TType _etype56;
+            xfer += iprot->readListBegin(_etype56, _size53);
+            this->columns.resize(_size53);
+            uint32_t _i57;
+            for (_i57 = 0; _i57 < _size53; ++_i57)
             {
-              xfer += this->columns[_i35].read(iprot);
+              xfer += this->columns[_i57].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1274,15 +1661,16 @@ uint32_t TTableSchema::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TTableSchema::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TTableSchema");
 
   xfer += oprot->writeFieldBegin("columns", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->columns.size()));
-    std::vector<TColumnDesc> ::const_iterator _iter36;
-    for (_iter36 = this->columns.begin(); _iter36 != this->columns.end(); ++_iter36)
+    std::vector<TColumnDesc> ::const_iterator _iter58;
+    for (_iter58 = this->columns.begin(); _iter58 != this->columns.end(); ++_iter58)
     {
-      xfer += (*_iter36).write(oprot);
+      xfer += (*_iter58).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1290,6 +1678,7 @@ uint32_t TTableSchema::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1298,6 +1687,31 @@ void swap(TTableSchema &a, TTableSchema &b) {
   swap(a.columns, b.columns);
 }
 
+TTableSchema::TTableSchema(const TTableSchema& other59) {
+  columns = other59.columns;
+}
+TTableSchema& TTableSchema::operator=(const TTableSchema& other60) {
+  columns = other60.columns;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TTableSchema& obj) {
+  using apache::thrift::to_string;
+  out << "TTableSchema(";
+  out << "columns=" << to_string(obj.columns);
+  out << ")";
+  return out;
+}
+
+
+TBoolValue::~TBoolValue() throw() {
+}
+
+
+void TBoolValue::__set_value(const bool val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TBoolValue::ascii_fingerprint = "BF054652DEF86253C2BEE7D947F167DD";
 const uint8_t TBoolValue::binary_fingerprint[16] = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
@@ -1343,6 +1757,7 @@ uint32_t TBoolValue::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TBoolValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TBoolValue");
 
   if (this->__isset.value) {
@@ -1352,6 +1767,7 @@ uint32_t TBoolValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1361,6 +1777,33 @@ void swap(TBoolValue &a, TBoolValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TBoolValue::TBoolValue(const TBoolValue& other61) {
+  value = other61.value;
+  __isset = other61.__isset;
+}
+TBoolValue& TBoolValue::operator=(const TBoolValue& other62) {
+  value = other62.value;
+  __isset = other62.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TBoolValue& obj) {
+  using apache::thrift::to_string;
+  out << "TBoolValue(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TByteValue::~TByteValue() throw() {
+}
+
+
+void TByteValue::__set_value(const int8_t val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TByteValue::ascii_fingerprint = "9C15298ACB5D04AEA9B52D5DDE6F9208";
 const uint8_t TByteValue::binary_fingerprint[16] = {0x9C,0x15,0x29,0x8A,0xCB,0x5D,0x04,0xAE,0xA9,0xB5,0x2D,0x5D,0xDE,0x6F,0x92,0x08};
 
@@ -1406,6 +1849,7 @@ uint32_t TByteValue::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TByteValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TByteValue");
 
   if (this->__isset.value) {
@@ -1415,6 +1859,7 @@ uint32_t TByteValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1424,6 +1869,33 @@ void swap(TByteValue &a, TByteValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TByteValue::TByteValue(const TByteValue& other63) {
+  value = other63.value;
+  __isset = other63.__isset;
+}
+TByteValue& TByteValue::operator=(const TByteValue& other64) {
+  value = other64.value;
+  __isset = other64.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TByteValue& obj) {
+  using apache::thrift::to_string;
+  out << "TByteValue(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TI16Value::~TI16Value() throw() {
+}
+
+
+void TI16Value::__set_value(const int16_t val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TI16Value::ascii_fingerprint = "5DAC9C51C7E1106BF936FC71860BE9D5";
 const uint8_t TI16Value::binary_fingerprint[16] = {0x5D,0xAC,0x9C,0x51,0xC7,0xE1,0x10,0x6B,0xF9,0x36,0xFC,0x71,0x86,0x0B,0xE9,0xD5};
 
@@ -1469,6 +1941,7 @@ uint32_t TI16Value::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI16Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI16Value");
 
   if (this->__isset.value) {
@@ -1478,6 +1951,7 @@ uint32_t TI16Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1487,6 +1961,33 @@ void swap(TI16Value &a, TI16Value &b) {
   swap(a.__isset, b.__isset);
 }
 
+TI16Value::TI16Value(const TI16Value& other65) {
+  value = other65.value;
+  __isset = other65.__isset;
+}
+TI16Value& TI16Value::operator=(const TI16Value& other66) {
+  value = other66.value;
+  __isset = other66.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI16Value& obj) {
+  using apache::thrift::to_string;
+  out << "TI16Value(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TI32Value::~TI32Value() throw() {
+}
+
+
+void TI32Value::__set_value(const int32_t val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TI32Value::ascii_fingerprint = "E7A96B151330359E84C0A3AC91BCBACD";
 const uint8_t TI32Value::binary_fingerprint[16] = {0xE7,0xA9,0x6B,0x15,0x13,0x30,0x35,0x9E,0x84,0xC0,0xA3,0xAC,0x91,0xBC,0xBA,0xCD};
 
@@ -1532,6 +2033,7 @@ uint32_t TI32Value::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI32Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI32Value");
 
   if (this->__isset.value) {
@@ -1541,6 +2043,7 @@ uint32_t TI32Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1550,6 +2053,33 @@ void swap(TI32Value &a, TI32Value &b) {
   swap(a.__isset, b.__isset);
 }
 
+TI32Value::TI32Value(const TI32Value& other67) {
+  value = other67.value;
+  __isset = other67.__isset;
+}
+TI32Value& TI32Value::operator=(const TI32Value& other68) {
+  value = other68.value;
+  __isset = other68.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI32Value& obj) {
+  using apache::thrift::to_string;
+  out << "TI32Value(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TI64Value::~TI64Value() throw() {
+}
+
+
+void TI64Value::__set_value(const int64_t val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TI64Value::ascii_fingerprint = "148F3AAAC1D9859963D5E800D187BF26";
 const uint8_t TI64Value::binary_fingerprint[16] = {0x14,0x8F,0x3A,0xAA,0xC1,0xD9,0x85,0x99,0x63,0xD5,0xE8,0x00,0xD1,0x87,0xBF,0x26};
 
@@ -1595,6 +2125,7 @@ uint32_t TI64Value::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI64Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI64Value");
 
   if (this->__isset.value) {
@@ -1604,6 +2135,7 @@ uint32_t TI64Value::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1613,6 +2145,33 @@ void swap(TI64Value &a, TI64Value &b) {
   swap(a.__isset, b.__isset);
 }
 
+TI64Value::TI64Value(const TI64Value& other69) {
+  value = other69.value;
+  __isset = other69.__isset;
+}
+TI64Value& TI64Value::operator=(const TI64Value& other70) {
+  value = other70.value;
+  __isset = other70.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI64Value& obj) {
+  using apache::thrift::to_string;
+  out << "TI64Value(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TDoubleValue::~TDoubleValue() throw() {
+}
+
+
+void TDoubleValue::__set_value(const double val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TDoubleValue::ascii_fingerprint = "3586E570A474C4A8603B4FF74903B3A6";
 const uint8_t TDoubleValue::binary_fingerprint[16] = {0x35,0x86,0xE5,0x70,0xA4,0x74,0xC4,0xA8,0x60,0x3B,0x4F,0xF7,0x49,0x03,0xB3,0xA6};
 
@@ -1658,6 +2217,7 @@ uint32_t TDoubleValue::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TDoubleValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TDoubleValue");
 
   if (this->__isset.value) {
@@ -1667,6 +2227,7 @@ uint32_t TDoubleValue::write(::apache::thrift::protocol::TProtocol* oprot) const
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1676,6 +2237,33 @@ void swap(TDoubleValue &a, TDoubleValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TDoubleValue::TDoubleValue(const TDoubleValue& other71) {
+  value = other71.value;
+  __isset = other71.__isset;
+}
+TDoubleValue& TDoubleValue::operator=(const TDoubleValue& other72) {
+  value = other72.value;
+  __isset = other72.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TDoubleValue& obj) {
+  using apache::thrift::to_string;
+  out << "TDoubleValue(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TStringValue::~TStringValue() throw() {
+}
+
+
+void TStringValue::__set_value(const std::string& val) {
+  this->value = val;
+__isset.value = true;
+}
+
 const char* TStringValue::ascii_fingerprint = "66E694018C17E5B65A59AE8F55CCA3CD";
 const uint8_t TStringValue::binary_fingerprint[16] = {0x66,0xE6,0x94,0x01,0x8C,0x17,0xE5,0xB6,0x5A,0x59,0xAE,0x8F,0x55,0xCC,0xA3,0xCD};
 
@@ -1721,6 +2309,7 @@ uint32_t TStringValue::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TStringValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TStringValue");
 
   if (this->__isset.value) {
@@ -1730,6 +2319,7 @@ uint32_t TStringValue::write(::apache::thrift::protocol::TProtocol* oprot) const
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1739,6 +2329,56 @@ void swap(TStringValue &a, TStringValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TStringValue::TStringValue(const TStringValue& other73) {
+  value = other73.value;
+  __isset = other73.__isset;
+}
+TStringValue& TStringValue::operator=(const TStringValue& other74) {
+  value = other74.value;
+  __isset = other74.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TStringValue& obj) {
+  using apache::thrift::to_string;
+  out << "TStringValue(";
+  out << "value="; (obj.__isset.value ? (out << to_string(obj.value)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TColumnValue::~TColumnValue() throw() {
+}
+
+
+void TColumnValue::__set_boolVal(const TBoolValue& val) {
+  this->boolVal = val;
+}
+
+void TColumnValue::__set_byteVal(const TByteValue& val) {
+  this->byteVal = val;
+}
+
+void TColumnValue::__set_i16Val(const TI16Value& val) {
+  this->i16Val = val;
+}
+
+void TColumnValue::__set_i32Val(const TI32Value& val) {
+  this->i32Val = val;
+}
+
+void TColumnValue::__set_i64Val(const TI64Value& val) {
+  this->i64Val = val;
+}
+
+void TColumnValue::__set_doubleVal(const TDoubleValue& val) {
+  this->doubleVal = val;
+}
+
+void TColumnValue::__set_stringVal(const TStringValue& val) {
+  this->stringVal = val;
+}
+
 const char* TColumnValue::ascii_fingerprint = "C2DDD988447EA7999A8285AA38AAE9AD";
 const uint8_t TColumnValue::binary_fingerprint[16] = {0xC2,0xDD,0xD9,0x88,0x44,0x7E,0xA7,0x99,0x9A,0x82,0x85,0xAA,0x38,0xAA,0xE9,0xAD};
 
@@ -1832,6 +2472,7 @@ uint32_t TColumnValue::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TColumnValue::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TColumnValue");
 
   xfer += oprot->writeFieldBegin("boolVal", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -1864,6 +2505,7 @@ uint32_t TColumnValue::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1879,6 +2521,50 @@ void swap(TColumnValue &a, TColumnValue &b) {
   swap(a.__isset, b.__isset);
 }
 
+TColumnValue::TColumnValue(const TColumnValue& other75) {
+  boolVal = other75.boolVal;
+  byteVal = other75.byteVal;
+  i16Val = other75.i16Val;
+  i32Val = other75.i32Val;
+  i64Val = other75.i64Val;
+  doubleVal = other75.doubleVal;
+  stringVal = other75.stringVal;
+  __isset = other75.__isset;
+}
+TColumnValue& TColumnValue::operator=(const TColumnValue& other76) {
+  boolVal = other76.boolVal;
+  byteVal = other76.byteVal;
+  i16Val = other76.i16Val;
+  i32Val = other76.i32Val;
+  i64Val = other76.i64Val;
+  doubleVal = other76.doubleVal;
+  stringVal = other76.stringVal;
+  __isset = other76.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TColumnValue& obj) {
+  using apache::thrift::to_string;
+  out << "TColumnValue(";
+  out << "boolVal=" << to_string(obj.boolVal);
+  out << ", " << "byteVal=" << to_string(obj.byteVal);
+  out << ", " << "i16Val=" << to_string(obj.i16Val);
+  out << ", " << "i32Val=" << to_string(obj.i32Val);
+  out << ", " << "i64Val=" << to_string(obj.i64Val);
+  out << ", " << "doubleVal=" << to_string(obj.doubleVal);
+  out << ", " << "stringVal=" << to_string(obj.stringVal);
+  out << ")";
+  return out;
+}
+
+
+TRow::~TRow() throw() {
+}
+
+
+void TRow::__set_colVals(const std::vector<TColumnValue> & val) {
+  this->colVals = val;
+}
+
 const char* TRow::ascii_fingerprint = "E73FD1FCA0CA58A669FC3E02FB68D534";
 const uint8_t TRow::binary_fingerprint[16] = {0xE7,0x3F,0xD1,0xFC,0xA0,0xCA,0x58,0xA6,0x69,0xFC,0x3E,0x02,0xFB,0x68,0xD5,0x34};
 
@@ -1907,14 +2593,14 @@ uint32_t TRow::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->colVals.clear();
-            uint32_t _size37;
-            ::apache::thrift::protocol::TType _etype40;
-            xfer += iprot->readListBegin(_etype40, _size37);
-            this->colVals.resize(_size37);
-            uint32_t _i41;
-            for (_i41 = 0; _i41 < _size37; ++_i41)
+            uint32_t _size77;
+            ::apache::thrift::protocol::TType _etype80;
+            xfer += iprot->readListBegin(_etype80, _size77);
+            this->colVals.resize(_size77);
+            uint32_t _i81;
+            for (_i81 = 0; _i81 < _size77; ++_i81)
             {
-              xfer += this->colVals[_i41].read(iprot);
+              xfer += this->colVals[_i81].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1939,15 +2625,16 @@ uint32_t TRow::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TRow::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TRow");
 
   xfer += oprot->writeFieldBegin("colVals", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->colVals.size()));
-    std::vector<TColumnValue> ::const_iterator _iter42;
-    for (_iter42 = this->colVals.begin(); _iter42 != this->colVals.end(); ++_iter42)
+    std::vector<TColumnValue> ::const_iterator _iter82;
+    for (_iter82 = this->colVals.begin(); _iter82 != this->colVals.end(); ++_iter82)
     {
-      xfer += (*_iter42).write(oprot);
+      xfer += (*_iter82).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1955,6 +2642,7 @@ uint32_t TRow::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1963,15 +2651,43 @@ void swap(TRow &a, TRow &b) {
   swap(a.colVals, b.colVals);
 }
 
-const char* TBoolColumn::ascii_fingerprint = "F9058324D96DB7F974D8ACDC01C54219";
-const uint8_t TBoolColumn::binary_fingerprint[16] = {0xF9,0x05,0x83,0x24,0xD9,0x6D,0xB7,0xF9,0x74,0xD8,0xAC,0xDC,0x01,0xC5,0x42,0x19};
+TRow::TRow(const TRow& other83) {
+  colVals = other83.colVals;
+}
+TRow& TRow::operator=(const TRow& other84) {
+  colVals = other84.colVals;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TRow& obj) {
+  using apache::thrift::to_string;
+  out << "TRow(";
+  out << "colVals=" << to_string(obj.colVals);
+  out << ")";
+  return out;
+}
 
-uint32_t TBoolColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
-  uint32_t xfer = 0;
-  std::string fname;
-  ::apache::thrift::protocol::TType ftype;
-  int16_t fid;
+TBoolColumn::~TBoolColumn() throw() {
+}
+
+
+void TBoolColumn::__set_values(const std::vector<bool> & val) {
+  this->values = val;
+}
+
+void TBoolColumn::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
+const char* TBoolColumn::ascii_fingerprint = "F9058324D96DB7F974D8ACDC01C54219";
+const uint8_t TBoolColumn::binary_fingerprint[16] = {0xF9,0x05,0x83,0x24,0xD9,0x6D,0xB7,0xF9,0x74,0xD8,0xAC,0xDC,0x01,0xC5,0x42,0x19};
+
+uint32_t TBoolColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
+
+  uint32_t xfer = 0;
+  std::string fname;
+  ::apache::thrift::protocol::TType ftype;
+  int16_t fid;
 
   xfer += iprot->readStructBegin(fname);
 
@@ -1992,14 +2708,14 @@ uint32_t TBoolColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size43;
-            ::apache::thrift::protocol::TType _etype46;
-            xfer += iprot->readListBegin(_etype46, _size43);
-            this->values.resize(_size43);
-            uint32_t _i47;
-            for (_i47 = 0; _i47 < _size43; ++_i47)
+            uint32_t _size85;
+            ::apache::thrift::protocol::TType _etype88;
+            xfer += iprot->readListBegin(_etype88, _size85);
+            this->values.resize(_size85);
+            uint32_t _i89;
+            for (_i89 = 0; _i89 < _size85; ++_i89)
             {
-              xfer += iprot->readBool(this->values[_i47]);
+              xfer += iprot->readBool(this->values[_i89]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2034,15 +2750,16 @@ uint32_t TBoolColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TBoolColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TBoolColumn");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_BOOL, static_cast<uint32_t>(this->values.size()));
-    std::vector<bool> ::const_iterator _iter48;
-    for (_iter48 = this->values.begin(); _iter48 != this->values.end(); ++_iter48)
+    std::vector<bool> ::const_iterator _iter90;
+    for (_iter90 = this->values.begin(); _iter90 != this->values.end(); ++_iter90)
     {
-      xfer += oprot->writeBool((*_iter48));
+      xfer += oprot->writeBool((*_iter90));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2054,6 +2771,7 @@ uint32_t TBoolColumn::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2063,6 +2781,37 @@ void swap(TBoolColumn &a, TBoolColumn &b) {
   swap(a.nulls, b.nulls);
 }
 
+TBoolColumn::TBoolColumn(const TBoolColumn& other91) {
+  values = other91.values;
+  nulls = other91.nulls;
+}
+TBoolColumn& TBoolColumn::operator=(const TBoolColumn& other92) {
+  values = other92.values;
+  nulls = other92.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TBoolColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TBoolColumn(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TByteColumn::~TByteColumn() throw() {
+}
+
+
+void TByteColumn::__set_values(const std::vector<int8_t> & val) {
+  this->values = val;
+}
+
+void TByteColumn::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TByteColumn::ascii_fingerprint = "1CB300106BAA463A70BB2A2395900F48";
 const uint8_t TByteColumn::binary_fingerprint[16] = {0x1C,0xB3,0x00,0x10,0x6B,0xAA,0x46,0x3A,0x70,0xBB,0x2A,0x23,0x95,0x90,0x0F,0x48};
 
@@ -2092,14 +2841,14 @@ uint32_t TByteColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size49;
-            ::apache::thrift::protocol::TType _etype52;
-            xfer += iprot->readListBegin(_etype52, _size49);
-            this->values.resize(_size49);
-            uint32_t _i53;
-            for (_i53 = 0; _i53 < _size49; ++_i53)
+            uint32_t _size93;
+            ::apache::thrift::protocol::TType _etype96;
+            xfer += iprot->readListBegin(_etype96, _size93);
+            this->values.resize(_size93);
+            uint32_t _i97;
+            for (_i97 = 0; _i97 < _size93; ++_i97)
             {
-              xfer += iprot->readByte(this->values[_i53]);
+              xfer += iprot->readByte(this->values[_i97]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2134,15 +2883,16 @@ uint32_t TByteColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TByteColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TByteColumn");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_BYTE, static_cast<uint32_t>(this->values.size()));
-    std::vector<int8_t> ::const_iterator _iter54;
-    for (_iter54 = this->values.begin(); _iter54 != this->values.end(); ++_iter54)
+    std::vector<int8_t> ::const_iterator _iter98;
+    for (_iter98 = this->values.begin(); _iter98 != this->values.end(); ++_iter98)
     {
-      xfer += oprot->writeByte((*_iter54));
+      xfer += oprot->writeByte((*_iter98));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2154,6 +2904,7 @@ uint32_t TByteColumn::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2163,6 +2914,37 @@ void swap(TByteColumn &a, TByteColumn &b) {
   swap(a.nulls, b.nulls);
 }
 
+TByteColumn::TByteColumn(const TByteColumn& other99) {
+  values = other99.values;
+  nulls = other99.nulls;
+}
+TByteColumn& TByteColumn::operator=(const TByteColumn& other100) {
+  values = other100.values;
+  nulls = other100.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TByteColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TByteColumn(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TI16Column::~TI16Column() throw() {
+}
+
+
+void TI16Column::__set_values(const std::vector<int16_t> & val) {
+  this->values = val;
+}
+
+void TI16Column::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TI16Column::ascii_fingerprint = "6574CDB1F121C8DB47FB257A3F104BDB";
 const uint8_t TI16Column::binary_fingerprint[16] = {0x65,0x74,0xCD,0xB1,0xF1,0x21,0xC8,0xDB,0x47,0xFB,0x25,0x7A,0x3F,0x10,0x4B,0xDB};
 
@@ -2192,14 +2974,14 @@ uint32_t TI16Column::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size55;
-            ::apache::thrift::protocol::TType _etype58;
-            xfer += iprot->readListBegin(_etype58, _size55);
-            this->values.resize(_size55);
-            uint32_t _i59;
-            for (_i59 = 0; _i59 < _size55; ++_i59)
+            uint32_t _size101;
+            ::apache::thrift::protocol::TType _etype104;
+            xfer += iprot->readListBegin(_etype104, _size101);
+            this->values.resize(_size101);
+            uint32_t _i105;
+            for (_i105 = 0; _i105 < _size101; ++_i105)
             {
-              xfer += iprot->readI16(this->values[_i59]);
+              xfer += iprot->readI16(this->values[_i105]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2234,15 +3016,16 @@ uint32_t TI16Column::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI16Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI16Column");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I16, static_cast<uint32_t>(this->values.size()));
-    std::vector<int16_t> ::const_iterator _iter60;
-    for (_iter60 = this->values.begin(); _iter60 != this->values.end(); ++_iter60)
+    std::vector<int16_t> ::const_iterator _iter106;
+    for (_iter106 = this->values.begin(); _iter106 != this->values.end(); ++_iter106)
     {
-      xfer += oprot->writeI16((*_iter60));
+      xfer += oprot->writeI16((*_iter106));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2254,6 +3037,7 @@ uint32_t TI16Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2263,6 +3047,37 @@ void swap(TI16Column &a, TI16Column &b) {
   swap(a.nulls, b.nulls);
 }
 
+TI16Column::TI16Column(const TI16Column& other107) {
+  values = other107.values;
+  nulls = other107.nulls;
+}
+TI16Column& TI16Column::operator=(const TI16Column& other108) {
+  values = other108.values;
+  nulls = other108.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI16Column& obj) {
+  using apache::thrift::to_string;
+  out << "TI16Column(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TI32Column::~TI32Column() throw() {
+}
+
+
+void TI32Column::__set_values(const std::vector<int32_t> & val) {
+  this->values = val;
+}
+
+void TI32Column::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TI32Column::ascii_fingerprint = "CCCCE89C7E9DA10280F5663700677313";
 const uint8_t TI32Column::binary_fingerprint[16] = {0xCC,0xCC,0xE8,0x9C,0x7E,0x9D,0xA1,0x02,0x80,0xF5,0x66,0x37,0x00,0x67,0x73,0x13};
 
@@ -2292,14 +3107,14 @@ uint32_t TI32Column::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size61;
-            ::apache::thrift::protocol::TType _etype64;
-            xfer += iprot->readListBegin(_etype64, _size61);
-            this->values.resize(_size61);
-            uint32_t _i65;
-            for (_i65 = 0; _i65 < _size61; ++_i65)
+            uint32_t _size109;
+            ::apache::thrift::protocol::TType _etype112;
+            xfer += iprot->readListBegin(_etype112, _size109);
+            this->values.resize(_size109);
+            uint32_t _i113;
+            for (_i113 = 0; _i113 < _size109; ++_i113)
             {
-              xfer += iprot->readI32(this->values[_i65]);
+              xfer += iprot->readI32(this->values[_i113]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2334,15 +3149,16 @@ uint32_t TI32Column::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI32Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI32Column");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I32, static_cast<uint32_t>(this->values.size()));
-    std::vector<int32_t> ::const_iterator _iter66;
-    for (_iter66 = this->values.begin(); _iter66 != this->values.end(); ++_iter66)
+    std::vector<int32_t> ::const_iterator _iter114;
+    for (_iter114 = this->values.begin(); _iter114 != this->values.end(); ++_iter114)
     {
-      xfer += oprot->writeI32((*_iter66));
+      xfer += oprot->writeI32((*_iter114));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2354,6 +3170,7 @@ uint32_t TI32Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2363,6 +3180,37 @@ void swap(TI32Column &a, TI32Column &b) {
   swap(a.nulls, b.nulls);
 }
 
+TI32Column::TI32Column(const TI32Column& other115) {
+  values = other115.values;
+  nulls = other115.nulls;
+}
+TI32Column& TI32Column::operator=(const TI32Column& other116) {
+  values = other116.values;
+  nulls = other116.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI32Column& obj) {
+  using apache::thrift::to_string;
+  out << "TI32Column(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TI64Column::~TI64Column() throw() {
+}
+
+
+void TI64Column::__set_values(const std::vector<int64_t> & val) {
+  this->values = val;
+}
+
+void TI64Column::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TI64Column::ascii_fingerprint = "925353917FC0AF87976A2338011F5A31";
 const uint8_t TI64Column::binary_fingerprint[16] = {0x92,0x53,0x53,0x91,0x7F,0xC0,0xAF,0x87,0x97,0x6A,0x23,0x38,0x01,0x1F,0x5A,0x31};
 
@@ -2392,14 +3240,14 @@ uint32_t TI64Column::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size67;
-            ::apache::thrift::protocol::TType _etype70;
-            xfer += iprot->readListBegin(_etype70, _size67);
-            this->values.resize(_size67);
-            uint32_t _i71;
-            for (_i71 = 0; _i71 < _size67; ++_i71)
+            uint32_t _size117;
+            ::apache::thrift::protocol::TType _etype120;
+            xfer += iprot->readListBegin(_etype120, _size117);
+            this->values.resize(_size117);
+            uint32_t _i121;
+            for (_i121 = 0; _i121 < _size117; ++_i121)
             {
-              xfer += iprot->readI64(this->values[_i71]);
+              xfer += iprot->readI64(this->values[_i121]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2434,15 +3282,16 @@ uint32_t TI64Column::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TI64Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TI64Column");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->values.size()));
-    std::vector<int64_t> ::const_iterator _iter72;
-    for (_iter72 = this->values.begin(); _iter72 != this->values.end(); ++_iter72)
+    std::vector<int64_t> ::const_iterator _iter122;
+    for (_iter122 = this->values.begin(); _iter122 != this->values.end(); ++_iter122)
     {
-      xfer += oprot->writeI64((*_iter72));
+      xfer += oprot->writeI64((*_iter122));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2454,6 +3303,7 @@ uint32_t TI64Column::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2463,6 +3313,37 @@ void swap(TI64Column &a, TI64Column &b) {
   swap(a.nulls, b.nulls);
 }
 
+TI64Column::TI64Column(const TI64Column& other123) {
+  values = other123.values;
+  nulls = other123.nulls;
+}
+TI64Column& TI64Column::operator=(const TI64Column& other124) {
+  values = other124.values;
+  nulls = other124.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TI64Column& obj) {
+  using apache::thrift::to_string;
+  out << "TI64Column(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TDoubleColumn::~TDoubleColumn() throw() {
+}
+
+
+void TDoubleColumn::__set_values(const std::vector<double> & val) {
+  this->values = val;
+}
+
+void TDoubleColumn::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TDoubleColumn::ascii_fingerprint = "8FF1C050A8D7FD247AEB23CD71539C09";
 const uint8_t TDoubleColumn::binary_fingerprint[16] = {0x8F,0xF1,0xC0,0x50,0xA8,0xD7,0xFD,0x24,0x7A,0xEB,0x23,0xCD,0x71,0x53,0x9C,0x09};
 
@@ -2492,14 +3373,14 @@ uint32_t TDoubleColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size73;
-            ::apache::thrift::protocol::TType _etype76;
-            xfer += iprot->readListBegin(_etype76, _size73);
-            this->values.resize(_size73);
-            uint32_t _i77;
-            for (_i77 = 0; _i77 < _size73; ++_i77)
+            uint32_t _size125;
+            ::apache::thrift::protocol::TType _etype128;
+            xfer += iprot->readListBegin(_etype128, _size125);
+            this->values.resize(_size125);
+            uint32_t _i129;
+            for (_i129 = 0; _i129 < _size125; ++_i129)
             {
-              xfer += iprot->readDouble(this->values[_i77]);
+              xfer += iprot->readDouble(this->values[_i129]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2534,15 +3415,16 @@ uint32_t TDoubleColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TDoubleColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TDoubleColumn");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_DOUBLE, static_cast<uint32_t>(this->values.size()));
-    std::vector<double> ::const_iterator _iter78;
-    for (_iter78 = this->values.begin(); _iter78 != this->values.end(); ++_iter78)
+    std::vector<double> ::const_iterator _iter130;
+    for (_iter130 = this->values.begin(); _iter130 != this->values.end(); ++_iter130)
     {
-      xfer += oprot->writeDouble((*_iter78));
+      xfer += oprot->writeDouble((*_iter130));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2554,6 +3436,7 @@ uint32_t TDoubleColumn::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2563,6 +3446,37 @@ void swap(TDoubleColumn &a, TDoubleColumn &b) {
   swap(a.nulls, b.nulls);
 }
 
+TDoubleColumn::TDoubleColumn(const TDoubleColumn& other131) {
+  values = other131.values;
+  nulls = other131.nulls;
+}
+TDoubleColumn& TDoubleColumn::operator=(const TDoubleColumn& other132) {
+  values = other132.values;
+  nulls = other132.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TDoubleColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TDoubleColumn(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TStringColumn::~TStringColumn() throw() {
+}
+
+
+void TStringColumn::__set_values(const std::vector<std::string> & val) {
+  this->values = val;
+}
+
+void TStringColumn::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TStringColumn::ascii_fingerprint = "BE556BF7091B2DABBA1863D5E458B15F";
 const uint8_t TStringColumn::binary_fingerprint[16] = {0xBE,0x55,0x6B,0xF7,0x09,0x1B,0x2D,0xAB,0xBA,0x18,0x63,0xD5,0xE4,0x58,0xB1,0x5F};
 
@@ -2592,14 +3506,14 @@ uint32_t TStringColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size79;
-            ::apache::thrift::protocol::TType _etype82;
-            xfer += iprot->readListBegin(_etype82, _size79);
-            this->values.resize(_size79);
-            uint32_t _i83;
-            for (_i83 = 0; _i83 < _size79; ++_i83)
+            uint32_t _size133;
+            ::apache::thrift::protocol::TType _etype136;
+            xfer += iprot->readListBegin(_etype136, _size133);
+            this->values.resize(_size133);
+            uint32_t _i137;
+            for (_i137 = 0; _i137 < _size133; ++_i137)
             {
-              xfer += iprot->readString(this->values[_i83]);
+              xfer += iprot->readString(this->values[_i137]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2634,15 +3548,16 @@ uint32_t TStringColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TStringColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TStringColumn");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->values.size()));
-    std::vector<std::string> ::const_iterator _iter84;
-    for (_iter84 = this->values.begin(); _iter84 != this->values.end(); ++_iter84)
+    std::vector<std::string> ::const_iterator _iter138;
+    for (_iter138 = this->values.begin(); _iter138 != this->values.end(); ++_iter138)
     {
-      xfer += oprot->writeString((*_iter84));
+      xfer += oprot->writeString((*_iter138));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2654,6 +3569,7 @@ uint32_t TStringColumn::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2663,6 +3579,37 @@ void swap(TStringColumn &a, TStringColumn &b) {
   swap(a.nulls, b.nulls);
 }
 
+TStringColumn::TStringColumn(const TStringColumn& other139) {
+  values = other139.values;
+  nulls = other139.nulls;
+}
+TStringColumn& TStringColumn::operator=(const TStringColumn& other140) {
+  values = other140.values;
+  nulls = other140.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TStringColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TStringColumn(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TBinaryColumn::~TBinaryColumn() throw() {
+}
+
+
+void TBinaryColumn::__set_values(const std::vector<std::string> & val) {
+  this->values = val;
+}
+
+void TBinaryColumn::__set_nulls(const std::string& val) {
+  this->nulls = val;
+}
+
 const char* TBinaryColumn::ascii_fingerprint = "BE556BF7091B2DABBA1863D5E458B15F";
 const uint8_t TBinaryColumn::binary_fingerprint[16] = {0xBE,0x55,0x6B,0xF7,0x09,0x1B,0x2D,0xAB,0xBA,0x18,0x63,0xD5,0xE4,0x58,0xB1,0x5F};
 
@@ -2692,14 +3639,14 @@ uint32_t TBinaryColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->values.clear();
-            uint32_t _size85;
-            ::apache::thrift::protocol::TType _etype88;
-            xfer += iprot->readListBegin(_etype88, _size85);
-            this->values.resize(_size85);
-            uint32_t _i89;
-            for (_i89 = 0; _i89 < _size85; ++_i89)
+            uint32_t _size141;
+            ::apache::thrift::protocol::TType _etype144;
+            xfer += iprot->readListBegin(_etype144, _size141);
+            this->values.resize(_size141);
+            uint32_t _i145;
+            for (_i145 = 0; _i145 < _size141; ++_i145)
             {
-              xfer += iprot->readBinary(this->values[_i89]);
+              xfer += iprot->readBinary(this->values[_i145]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2734,15 +3681,16 @@ uint32_t TBinaryColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TBinaryColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TBinaryColumn");
 
   xfer += oprot->writeFieldBegin("values", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->values.size()));
-    std::vector<std::string> ::const_iterator _iter90;
-    for (_iter90 = this->values.begin(); _iter90 != this->values.end(); ++_iter90)
+    std::vector<std::string> ::const_iterator _iter146;
+    for (_iter146 = this->values.begin(); _iter146 != this->values.end(); ++_iter146)
     {
-      xfer += oprot->writeBinary((*_iter90));
+      xfer += oprot->writeBinary((*_iter146));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2754,6 +3702,7 @@ uint32_t TBinaryColumn::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2763,6 +3712,61 @@ void swap(TBinaryColumn &a, TBinaryColumn &b) {
   swap(a.nulls, b.nulls);
 }
 
+TBinaryColumn::TBinaryColumn(const TBinaryColumn& other147) {
+  values = other147.values;
+  nulls = other147.nulls;
+}
+TBinaryColumn& TBinaryColumn::operator=(const TBinaryColumn& other148) {
+  values = other148.values;
+  nulls = other148.nulls;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TBinaryColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TBinaryColumn(";
+  out << "values=" << to_string(obj.values);
+  out << ", " << "nulls=" << to_string(obj.nulls);
+  out << ")";
+  return out;
+}
+
+
+TColumn::~TColumn() throw() {
+}
+
+
+void TColumn::__set_boolVal(const TBoolColumn& val) {
+  this->boolVal = val;
+}
+
+void TColumn::__set_byteVal(const TByteColumn& val) {
+  this->byteVal = val;
+}
+
+void TColumn::__set_i16Val(const TI16Column& val) {
+  this->i16Val = val;
+}
+
+void TColumn::__set_i32Val(const TI32Column& val) {
+  this->i32Val = val;
+}
+
+void TColumn::__set_i64Val(const TI64Column& val) {
+  this->i64Val = val;
+}
+
+void TColumn::__set_doubleVal(const TDoubleColumn& val) {
+  this->doubleVal = val;
+}
+
+void TColumn::__set_stringVal(const TStringColumn& val) {
+  this->stringVal = val;
+}
+
+void TColumn::__set_binaryVal(const TBinaryColumn& val) {
+  this->binaryVal = val;
+}
+
 const char* TColumn::ascii_fingerprint = "E6ADD10B4CDDE61A19E8878CC7039A17";
 const uint8_t TColumn::binary_fingerprint[16] = {0xE6,0xAD,0xD1,0x0B,0x4C,0xDD,0xE6,0x1A,0x19,0xE8,0x87,0x8C,0xC7,0x03,0x9A,0x17};
 
@@ -2864,6 +3868,7 @@ uint32_t TColumn::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TColumn");
 
   xfer += oprot->writeFieldBegin("boolVal", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -2900,6 +3905,7 @@ uint32_t TColumn::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2916,6 +3922,62 @@ void swap(TColumn &a, TColumn &b) {
   swap(a.__isset, b.__isset);
 }
 
+TColumn::TColumn(const TColumn& other149) {
+  boolVal = other149.boolVal;
+  byteVal = other149.byteVal;
+  i16Val = other149.i16Val;
+  i32Val = other149.i32Val;
+  i64Val = other149.i64Val;
+  doubleVal = other149.doubleVal;
+  stringVal = other149.stringVal;
+  binaryVal = other149.binaryVal;
+  __isset = other149.__isset;
+}
+TColumn& TColumn::operator=(const TColumn& other150) {
+  boolVal = other150.boolVal;
+  byteVal = other150.byteVal;
+  i16Val = other150.i16Val;
+  i32Val = other150.i32Val;
+  i64Val = other150.i64Val;
+  doubleVal = other150.doubleVal;
+  stringVal = other150.stringVal;
+  binaryVal = other150.binaryVal;
+  __isset = other150.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TColumn& obj) {
+  using apache::thrift::to_string;
+  out << "TColumn(";
+  out << "boolVal=" << to_string(obj.boolVal);
+  out << ", " << "byteVal=" << to_string(obj.byteVal);
+  out << ", " << "i16Val=" << to_string(obj.i16Val);
+  out << ", " << "i32Val=" << to_string(obj.i32Val);
+  out << ", " << "i64Val=" << to_string(obj.i64Val);
+  out << ", " << "doubleVal=" << to_string(obj.doubleVal);
+  out << ", " << "stringVal=" << to_string(obj.stringVal);
+  out << ", " << "binaryVal=" << to_string(obj.binaryVal);
+  out << ")";
+  return out;
+}
+
+
+TRowSet::~TRowSet() throw() {
+}
+
+
+void TRowSet::__set_startRowOffset(const int64_t val) {
+  this->startRowOffset = val;
+}
+
+void TRowSet::__set_rows(const std::vector<TRow> & val) {
+  this->rows = val;
+}
+
+void TRowSet::__set_columns(const std::vector<TColumn> & val) {
+  this->columns = val;
+__isset.columns = true;
+}
+
 const char* TRowSet::ascii_fingerprint = "46DA30A870489C7A58105AE0080DAEBF";
 const uint8_t TRowSet::binary_fingerprint[16] = {0x46,0xDA,0x30,0xA8,0x70,0x48,0x9C,0x7A,0x58,0x10,0x5A,0xE0,0x08,0x0D,0xAE,0xBF};
 
@@ -2953,14 +4015,14 @@ uint32_t TRowSet::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->rows.clear();
-            uint32_t _size91;
-            ::apache::thrift::protocol::TType _etype94;
-            xfer += iprot->readListBegin(_etype94, _size91);
-            this->rows.resize(_size91);
-            uint32_t _i95;
-            for (_i95 = 0; _i95 < _size91; ++_i95)
+            uint32_t _size151;
+            ::apache::thrift::protocol::TType _etype154;
+            xfer += iprot->readListBegin(_etype154, _size151);
+            this->rows.resize(_size151);
+            uint32_t _i155;
+            for (_i155 = 0; _i155 < _size151; ++_i155)
             {
-              xfer += this->rows[_i95].read(iprot);
+              xfer += this->rows[_i155].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -2973,14 +4035,14 @@ uint32_t TRowSet::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->columns.clear();
-            uint32_t _size96;
-            ::apache::thrift::protocol::TType _etype99;
-            xfer += iprot->readListBegin(_etype99, _size96);
-            this->columns.resize(_size96);
-            uint32_t _i100;
-            for (_i100 = 0; _i100 < _size96; ++_i100)
+            uint32_t _size156;
+            ::apache::thrift::protocol::TType _etype159;
+            xfer += iprot->readListBegin(_etype159, _size156);
+            this->columns.resize(_size156);
+            uint32_t _i160;
+            for (_i160 = 0; _i160 < _size156; ++_i160)
             {
-              xfer += this->columns[_i100].read(iprot);
+              xfer += this->columns[_i160].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -3007,6 +4069,7 @@ uint32_t TRowSet::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TRowSet::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TRowSet");
 
   xfer += oprot->writeFieldBegin("startRowOffset", ::apache::thrift::protocol::T_I64, 1);
@@ -3016,10 +4079,10 @@ uint32_t TRowSet::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("rows", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->rows.size()));
-    std::vector<TRow> ::const_iterator _iter101;
-    for (_iter101 = this->rows.begin(); _iter101 != this->rows.end(); ++_iter101)
+    std::vector<TRow> ::const_iterator _iter161;
+    for (_iter161 = this->rows.begin(); _iter161 != this->rows.end(); ++_iter161)
     {
-      xfer += (*_iter101).write(oprot);
+      xfer += (*_iter161).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -3029,10 +4092,10 @@ uint32_t TRowSet::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("columns", ::apache::thrift::protocol::T_LIST, 3);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->columns.size()));
-      std::vector<TColumn> ::const_iterator _iter102;
-      for (_iter102 = this->columns.begin(); _iter102 != this->columns.end(); ++_iter102)
+      std::vector<TColumn> ::const_iterator _iter162;
+      for (_iter162 = this->columns.begin(); _iter162 != this->columns.end(); ++_iter162)
       {
-        xfer += (*_iter102).write(oprot);
+        xfer += (*_iter162).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -3040,6 +4103,7 @@ uint32_t TRowSet::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -3051,6 +4115,58 @@ void swap(TRowSet &a, TRowSet &b) {
   swap(a.__isset, b.__isset);
 }
 
+TRowSet::TRowSet(const TRowSet& other163) {
+  startRowOffset = other163.startRowOffset;
+  rows = other163.rows;
+  columns = other163.columns;
+  __isset = other163.__isset;
+}
+TRowSet& TRowSet::operator=(const TRowSet& other164) {
+  startRowOffset = other164.startRowOffset;
+  rows = other164.rows;
+  columns = other164.columns;
+  __isset = other164.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TRowSet& obj) {
+  using apache::thrift::to_string;
+  out << "TRowSet(";
+  out << "startRowOffset=" << to_string(obj.startRowOffset);
+  out << ", " << "rows=" << to_string(obj.rows);
+  out << ", " << "columns="; (obj.__isset.columns ? (out << to_string(obj.columns)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+TStatus::~TStatus() throw() {
+}
+
+
+void TStatus::__set_statusCode(const TStatusCode::type val) {
+  this->statusCode = val;
+}
+
+void TStatus::__set_infoMessages(const std::vector<std::string> & val) {
+  this->infoMessages = val;
+__isset.infoMessages = true;
+}
+
+void TStatus::__set_sqlState(const std::string& val) {
+  this->sqlState = val;
+__isset.sqlState = true;
+}
+
+void TStatus::__set_errorCode(const int32_t val) {
+  this->errorCode = val;
+__isset.errorCode = true;
+}
+
+void TStatus::__set_errorMessage(const std::string& val) {
+  this->errorMessage = val;
+__isset.errorMessage = true;
+}
+
 const char* TStatus::ascii_fingerprint = "D5DEF49634A59C615C1B3A6F7D0DADB5";
 const uint8_t TStatus::binary_fingerprint[16] = {0xD5,0xDE,0xF4,0x96,0x34,0xA5,0x9C,0x61,0x5C,0x1B,0x3A,0x6F,0x7D,0x0D,0xAD,0xB5};
 
@@ -3077,9 +4193,9 @@ uint32_t TStatus::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast103;
-          xfer += iprot->readI32(ecast103);
-          this->statusCode = (TStatusCode::type)ecast103;
+          int32_t ecast165;
+          xfer += iprot->readI32(ecast165);
+          this->statusCode = (TStatusCode::type)ecast165;
           isset_statusCode = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -3089,14 +4205,14 @@ uint32_t TStatus::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->infoMessages.clear();
-            uint32_t _size104;
-            ::apache::thrift::protocol::TType _etype107;
-            xfer += iprot->readListBegin(_etype107, _size104);
-            this->infoMessages.resize(_size104);
-            uint32_t _i108;
-            for (_i108 = 0; _i108 < _size104; ++_i108)
+            uint32_t _size166;
+            ::apache::thrift::protocol::TType _etype169;
+            xfer += iprot->readListBegin(_etype169, _size166);
+            this->infoMessages.resize(_size166);
+            uint32_t _i170;
+            for (_i170 = 0; _i170 < _size166; ++_i170)
             {
-              xfer += iprot->readString(this->infoMessages[_i108]);
+              xfer += iprot->readString(this->infoMessages[_i170]);
             }
             xfer += iprot->readListEnd();
           }
@@ -3145,6 +4261,7 @@ uint32_t TStatus::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t TStatus::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("TStatus");
 
   xfer += oprot->writeFieldBegin("statusCode", ::apache::thrift::protocol::T_I32, 1);
@@ -3155,10 +4272,10 @@ uint32_t TStatus::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("infoMessages", ::apache::thrift::protocol::T_LIST, 2);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->infoMessages.size()));
-      std::vector<std::string> ::const_iterator _iter109;
-      for (_iter109 = this->infoMessages.begin(); _iter109 != this->infoMessages.end(); ++_iter109)
+      std::vector<std::string> ::const_iterator _iter171;
+      for (_iter171 = this->infoMessages.begin(); _iter171 != this->infoMessages.end(); ++_iter171)
       {
-        xfer += oprot->writeString((*_iter109));
+        xfer += oprot->writeString((*_iter171));
       }
       xfer += oprot->writeListEnd();
     }
@@ -3181,6 +4298,7 @@ uint32_t TStatus::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -3194,6 +4312,48 @@ void swap(TStatus &a, TStatus &b) {
   swap(a.__isset, b.__isset);
 }
 
+TStatus::TStatus(const TStatus& other172) {
+  statusCode = other172.statusCode;
+  infoMessages = other172.infoMessages;
+  sqlState = other172.sqlState;
+  errorCode = other172.errorCode;
+  errorMessage = other172.errorMessage;
+  __isset = other172.__isset;
+}
+TStatus& TStatus::operator=(const TStatus& other173) {
+  statusCode = other173.statusCode;
+  infoMessages = other173.infoMessages;
+  sqlState = other173.sqlState;
+  errorCode = other173.errorCode;
+  errorMessage = other173.errorMessage;
+  __isset = other173.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const TStatus& obj) {
+  using apache::thrift::to_string;
+  out << "TStatus(";
+  out << "statusCode=" << to_string(obj.statusCode);
+  out << ", " << "infoMessages="; (obj.__isset.infoMessages ? (out << to_string(obj.infoMessages)) : (out << "<null>"));
+  out << ", " << "sqlState="; (obj.__isset.sqlState ? (out << to_string(obj.sqlState)) : (out << "<null>"));
+  out << ", " << "errorCode="; (obj.__isset.errorCode ? (out << to_string(obj.errorCode)) : (out << "<null>"));
+  out << ", " << "errorMessage="; (obj.__isset.errorMessage ? (out << to_string(obj.errorMessage)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+THandleIdentifier::~THandleIdentifier() throw() {
+}
+
+
+void THandleIdentifier::__set_guid(const std::string& val) {
+  this->guid = val;
+}
+
+void THandleIdentifier::__set_secret(const std::string& val) {
+  this->secret = val;
+}
+
 const char* THandleIdentifier::ascii_fingerprint = "07A9615F837F7D0A952B595DD

<TRUNCATED>

[07/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIServiceConstants.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIServiceConstants.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIServiceConstants.java
index 25a38b1..046eb15 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIServiceConstants.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCLIServiceConstants.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TCLIServiceConstants {
 
   public static final Set<TTypeId> PRIMITIVE_TYPES = new HashSet<TTypeId>();

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenReq.java
index e23fcdd..8c5704b 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCancelDelegationTokenReq implements org.apache.thrift.TBase<TCancelDelegationTokenReq, TCancelDelegationTokenReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCancelDelegationTokenReq implements org.apache.thrift.TBase<TCancelDelegationTokenReq, TCancelDelegationTokenReq._Fields>, java.io.Serializable, Cloneable, Comparable<TCancelDelegationTokenReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCancelDelegationTokenReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -283,45 +287,45 @@ public class TCancelDelegationTokenReq implements org.apache.thrift.TBase<TCance
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_delegationToken = true && (isSetDelegationToken());
-    builder.append(present_delegationToken);
+    list.add(present_delegationToken);
     if (present_delegationToken)
-      builder.append(delegationToken);
+      list.add(delegationToken);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCancelDelegationTokenReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCancelDelegationTokenReq typedOther = (TCancelDelegationTokenReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(typedOther.isSetDelegationToken());
+    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(other.isSetDelegationToken());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDelegationToken()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, typedOther.delegationToken);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, other.delegationToken);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenResp.java
index 77c9ee7..ed2daff 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelDelegationTokenResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCancelDelegationTokenResp implements org.apache.thrift.TBase<TCancelDelegationTokenResp, TCancelDelegationTokenResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCancelDelegationTokenResp implements org.apache.thrift.TBase<TCancelDelegationTokenResp, TCancelDelegationTokenResp._Fields>, java.io.Serializable, Cloneable, Comparable<TCancelDelegationTokenResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCancelDelegationTokenResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCancelDelegationTokenResp implements org.apache.thrift.TBase<TCanc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCancelDelegationTokenResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCancelDelegationTokenResp typedOther = (TCancelDelegationTokenResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationReq.java
index 45eac48..b6ea659 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCancelOperationReq implements org.apache.thrift.TBase<TCancelOperationReq, TCancelOperationReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCancelOperationReq implements org.apache.thrift.TBase<TCancelOperationReq, TCancelOperationReq._Fields>, java.io.Serializable, Cloneable, Comparable<TCancelOperationReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCancelOperationReq");
 
   private static final org.apache.thrift.protocol.TField OPERATION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("operationHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCancelOperationReq implements org.apache.thrift.TBase<TCancelOpera
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCancelOperationReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCancelOperationReq typedOther = (TCancelOperationReq)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationResp.java
index 2a39414..4562d3e 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCancelOperationResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCancelOperationResp implements org.apache.thrift.TBase<TCancelOperationResp, TCancelOperationResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCancelOperationResp implements org.apache.thrift.TBase<TCancelOperationResp, TCancelOperationResp._Fields>, java.io.Serializable, Cloneable, Comparable<TCancelOperationResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCancelOperationResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCancelOperationResp implements org.apache.thrift.TBase<TCancelOper
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCancelOperationResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCancelOperationResp typedOther = (TCancelOperationResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationReq.java
index 0cbb7cc..202119c 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCloseOperationReq implements org.apache.thrift.TBase<TCloseOperationReq, TCloseOperationReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCloseOperationReq implements org.apache.thrift.TBase<TCloseOperationReq, TCloseOperationReq._Fields>, java.io.Serializable, Cloneable, Comparable<TCloseOperationReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCloseOperationReq");
 
   private static final org.apache.thrift.protocol.TField OPERATION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("operationHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCloseOperationReq implements org.apache.thrift.TBase<TCloseOperati
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCloseOperationReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCloseOperationReq typedOther = (TCloseOperationReq)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationResp.java
index 7334d67..93fc01d 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseOperationResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCloseOperationResp implements org.apache.thrift.TBase<TCloseOperationResp, TCloseOperationResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCloseOperationResp implements org.apache.thrift.TBase<TCloseOperationResp, TCloseOperationResp._Fields>, java.io.Serializable, Cloneable, Comparable<TCloseOperationResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCloseOperationResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCloseOperationResp implements org.apache.thrift.TBase<TCloseOperat
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCloseOperationResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCloseOperationResp typedOther = (TCloseOperationResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionReq.java
index 027e829..ce9637e 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCloseSessionReq implements org.apache.thrift.TBase<TCloseSessionReq, TCloseSessionReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCloseSessionReq implements org.apache.thrift.TBase<TCloseSessionReq, TCloseSessionReq._Fields>, java.io.Serializable, Cloneable, Comparable<TCloseSessionReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCloseSessionReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCloseSessionReq implements org.apache.thrift.TBase<TCloseSessionRe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCloseSessionReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCloseSessionReq typedOther = (TCloseSessionReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionResp.java
index 168c8fc..97f4073 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TCloseSessionResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TCloseSessionResp implements org.apache.thrift.TBase<TCloseSessionResp, TCloseSessionResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TCloseSessionResp implements org.apache.thrift.TBase<TCloseSessionResp, TCloseSessionResp._Fields>, java.io.Serializable, Cloneable, Comparable<TCloseSessionResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TCloseSessionResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TCloseSessionResp implements org.apache.thrift.TBase<TCloseSessionR
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TCloseSessionResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TCloseSessionResp typedOther = (TCloseSessionResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumn.java
index bfe50c7..1bda69d 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TColumn extends org.apache.thrift.TUnion<TColumn, TColumn._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumn");
   private static final org.apache.thrift.protocol.TField BOOL_VAL_FIELD_DESC = new org.apache.thrift.protocol.TField("boolVal", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -345,6 +348,7 @@ public class TColumn extends org.apache.thrift.TUnion<TColumn, TColumn._Fields>
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -697,19 +701,19 @@ public class TColumn extends org.apache.thrift.TUnion<TColumn, TColumn._Fields>
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnDesc.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnDesc.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnDesc.java
index 247db64..c5f6c47 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnDesc.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnDesc.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TColumnDesc implements org.apache.thrift.TBase<TColumnDesc, TColumnDesc._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TColumnDesc implements org.apache.thrift.TBase<TColumnDesc, TColumnDesc._Fields>, java.io.Serializable, Cloneable, Comparable<TColumnDesc> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumnDesc");
 
   private static final org.apache.thrift.protocol.TField COLUMN_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("columnName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -120,7 +124,7 @@ public class TColumnDesc implements org.apache.thrift.TBase<TColumnDesc, TColumn
   // isset id assignments
   private static final int __POSITION_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.COMMENT};
+  private static final _Fields optionals[] = {_Fields.COMMENT};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -400,75 +404,75 @@ public class TColumnDesc implements org.apache.thrift.TBase<TColumnDesc, TColumn
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_columnName = true && (isSetColumnName());
-    builder.append(present_columnName);
+    list.add(present_columnName);
     if (present_columnName)
-      builder.append(columnName);
+      list.add(columnName);
 
     boolean present_typeDesc = true && (isSetTypeDesc());
-    builder.append(present_typeDesc);
+    list.add(present_typeDesc);
     if (present_typeDesc)
-      builder.append(typeDesc);
+      list.add(typeDesc);
 
     boolean present_position = true;
-    builder.append(present_position);
+    list.add(present_position);
     if (present_position)
-      builder.append(position);
+      list.add(position);
 
     boolean present_comment = true && (isSetComment());
-    builder.append(present_comment);
+    list.add(present_comment);
     if (present_comment)
-      builder.append(comment);
+      list.add(comment);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TColumnDesc other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TColumnDesc typedOther = (TColumnDesc)other;
 
-    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(typedOther.isSetColumnName());
+    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(other.isSetColumnName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColumnName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, typedOther.columnName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, other.columnName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTypeDesc()).compareTo(typedOther.isSetTypeDesc());
+    lastComparison = Boolean.valueOf(isSetTypeDesc()).compareTo(other.isSetTypeDesc());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTypeDesc()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeDesc, typedOther.typeDesc);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeDesc, other.typeDesc);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPosition()).compareTo(typedOther.isSetPosition());
+    lastComparison = Boolean.valueOf(isSetPosition()).compareTo(other.isSetPosition());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPosition()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.position, typedOther.position);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.position, other.position);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetComment()).compareTo(typedOther.isSetComment());
+    lastComparison = Boolean.valueOf(isSetComment()).compareTo(other.isSetComment());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetComment()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comment, typedOther.comment);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comment, other.comment);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnValue.java
index 44da2cd..61aee4d 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TColumnValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class TColumnValue extends org.apache.thrift.TUnion<TColumnValue, TColumnValue._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TColumnValue");
   private static final org.apache.thrift.protocol.TField BOOL_VAL_FIELD_DESC = new org.apache.thrift.protocol.TField("boolVal", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -318,6 +321,7 @@ public class TColumnValue extends org.apache.thrift.TUnion<TColumnValue, TColumn
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -636,19 +640,19 @@ public class TColumnValue extends org.apache.thrift.TUnion<TColumnValue, TColumn
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleColumn.java
index 4fc5454..c9bae1c 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDoubleColumn._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDoubleColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TDoubleColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TDoubleColumn");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
    */
   public TDoubleColumn(TDoubleColumn other) {
     if (other.isSetValues()) {
-      List<Double> __this__values = new ArrayList<Double>();
-      for (Double other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Double> __this__values = new ArrayList<Double>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TDoubleColumn other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TDoubleColumn typedOther = (TDoubleColumn)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
               {
                 org.apache.thrift.protocol.TList _list94 = iprot.readListBegin();
                 struct.values = new ArrayList<Double>(_list94.size);
-                for (int _i95 = 0; _i95 < _list94.size; ++_i95)
+                double _elem95;
+                for (int _i96 = 0; _i96 < _list94.size; ++_i96)
                 {
-                  double _elem96; // optional
-                  _elem96 = iprot.readDouble();
-                  struct.values.add(_elem96);
+                  _elem95 = iprot.readDouble();
+                  struct.values.add(_elem95);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TDoubleColumn implements org.apache.thrift.TBase<TDoubleColumn, TDo
       {
         org.apache.thrift.protocol.TList _list99 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.DOUBLE, iprot.readI32());
         struct.values = new ArrayList<Double>(_list99.size);
-        for (int _i100 = 0; _i100 < _list99.size; ++_i100)
+        double _elem100;
+        for (int _i101 = 0; _i101 < _list99.size; ++_i101)
         {
-          double _elem101; // optional
-          _elem101 = iprot.readDouble();
-          struct.values.add(_elem101);
+          _elem100 = iprot.readDouble();
+          struct.values.add(_elem100);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleValue.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleValue.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleValue.java
index d215736..d633eca 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleValue.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TDoubleValue.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TDoubleValue implements org.apache.thrift.TBase<TDoubleValue, TDoubleValue._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TDoubleValue implements org.apache.thrift.TBase<TDoubleValue, TDoubleValue._Fields>, java.io.Serializable, Cloneable, Comparable<TDoubleValue> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TDoubleValue");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.DOUBLE, (short)1);
@@ -105,7 +109,7 @@ public class TDoubleValue implements org.apache.thrift.TBase<TDoubleValue, TDoub
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TDoubleValue implements org.apache.thrift.TBase<TDoubleValue, TDoub
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TDoubleValue other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TDoubleValue typedOther = (TDoubleValue)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementReq.java
index 4f157ad..8184895 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteStatementReq, TExecuteStatementReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteStatementReq, TExecuteStatementReq._Fields>, java.io.Serializable, Cloneable, Comparable<TExecuteStatementReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TExecuteStatementReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -120,7 +124,7 @@ public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteSta
   // isset id assignments
   private static final int __RUNASYNC_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.CONF_OVERLAY,_Fields.RUN_ASYNC};
+  private static final _Fields optionals[] = {_Fields.CONF_OVERLAY,_Fields.RUN_ASYNC};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -164,18 +168,7 @@ public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteSta
       this.statement = other.statement;
     }
     if (other.isSetConfOverlay()) {
-      Map<String,String> __this__confOverlay = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.confOverlay.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__confOverlay_copy_key = other_element_key;
-
-        String __this__confOverlay_copy_value = other_element_value;
-
-        __this__confOverlay.put(__this__confOverlay_copy_key, __this__confOverlay_copy_value);
-      }
+      Map<String,String> __this__confOverlay = new HashMap<String,String>(other.confOverlay);
       this.confOverlay = __this__confOverlay;
     }
     this.runAsync = other.runAsync;
@@ -424,75 +417,75 @@ public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteSta
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_statement = true && (isSetStatement());
-    builder.append(present_statement);
+    list.add(present_statement);
     if (present_statement)
-      builder.append(statement);
+      list.add(statement);
 
     boolean present_confOverlay = true && (isSetConfOverlay());
-    builder.append(present_confOverlay);
+    list.add(present_confOverlay);
     if (present_confOverlay)
-      builder.append(confOverlay);
+      list.add(confOverlay);
 
     boolean present_runAsync = true && (isSetRunAsync());
-    builder.append(present_runAsync);
+    list.add(present_runAsync);
     if (present_runAsync)
-      builder.append(runAsync);
+      list.add(runAsync);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TExecuteStatementReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TExecuteStatementReq typedOther = (TExecuteStatementReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetStatement()).compareTo(typedOther.isSetStatement());
+    lastComparison = Boolean.valueOf(isSetStatement()).compareTo(other.isSetStatement());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatement()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statement, typedOther.statement);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statement, other.statement);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetConfOverlay()).compareTo(typedOther.isSetConfOverlay());
+    lastComparison = Boolean.valueOf(isSetConfOverlay()).compareTo(other.isSetConfOverlay());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetConfOverlay()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.confOverlay, typedOther.confOverlay);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.confOverlay, other.confOverlay);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRunAsync()).compareTo(typedOther.isSetRunAsync());
+    lastComparison = Boolean.valueOf(isSetRunAsync()).compareTo(other.isSetRunAsync());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRunAsync()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runAsync, typedOther.runAsync);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runAsync, other.runAsync);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -626,13 +619,13 @@ public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteSta
               {
                 org.apache.thrift.protocol.TMap _map162 = iprot.readMapBegin();
                 struct.confOverlay = new HashMap<String,String>(2*_map162.size);
-                for (int _i163 = 0; _i163 < _map162.size; ++_i163)
+                String _key163;
+                String _val164;
+                for (int _i165 = 0; _i165 < _map162.size; ++_i165)
                 {
-                  String _key164; // required
-                  String _val165; // required
-                  _key164 = iprot.readString();
-                  _val165 = iprot.readString();
-                  struct.confOverlay.put(_key164, _val165);
+                  _key163 = iprot.readString();
+                  _val164 = iprot.readString();
+                  struct.confOverlay.put(_key163, _val164);
                 }
                 iprot.readMapEnd();
               }
@@ -747,13 +740,13 @@ public class TExecuteStatementReq implements org.apache.thrift.TBase<TExecuteSta
         {
           org.apache.thrift.protocol.TMap _map168 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.confOverlay = new HashMap<String,String>(2*_map168.size);
-          for (int _i169 = 0; _i169 < _map168.size; ++_i169)
+          String _key169;
+          String _val170;
+          for (int _i171 = 0; _i171 < _map168.size; ++_i171)
           {
-            String _key170; // required
-            String _val171; // required
-            _key170 = iprot.readString();
-            _val171 = iprot.readString();
-            struct.confOverlay.put(_key170, _val171);
+            _key169 = iprot.readString();
+            _val170 = iprot.readString();
+            struct.confOverlay.put(_key169, _val170);
           }
         }
         struct.setConfOverlayIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementResp.java
index fdde51e..0ddf82a 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TExecuteStatementResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TExecuteStatementResp implements org.apache.thrift.TBase<TExecuteStatementResp, TExecuteStatementResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TExecuteStatementResp implements org.apache.thrift.TBase<TExecuteStatementResp, TExecuteStatementResp._Fields>, java.io.Serializable, Cloneable, Comparable<TExecuteStatementResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TExecuteStatementResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TExecuteStatementResp implements org.apache.thrift.TBase<TExecuteSt
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TExecuteStatementResp implements org.apache.thrift.TBase<TExecuteSt
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TExecuteStatementResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TExecuteStatementResp typedOther = (TExecuteStatementResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchOrientation.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchOrientation.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchOrientation.java
index b2a22ef..64713e8 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchOrientation.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchOrientation.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsReq.java
index 068711f..87cbe12 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TFetchResultsReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsReq, TFetchResultsReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsReq, TFetchResultsReq._Fields>, java.io.Serializable, Cloneable, Comparable<TFetchResultsReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TFetchResultsReq");
 
   private static final org.apache.thrift.protocol.TField OPERATION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("operationHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -125,7 +129,7 @@ public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsRe
   private static final int __MAXROWS_ISSET_ID = 0;
   private static final int __FETCHTYPE_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.FETCH_TYPE};
+  private static final _Fields optionals[] = {_Fields.FETCH_TYPE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -416,75 +420,75 @@ public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsRe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
     boolean present_orientation = true && (isSetOrientation());
-    builder.append(present_orientation);
+    list.add(present_orientation);
     if (present_orientation)
-      builder.append(orientation.getValue());
+      list.add(orientation.getValue());
 
     boolean present_maxRows = true;
-    builder.append(present_maxRows);
+    list.add(present_maxRows);
     if (present_maxRows)
-      builder.append(maxRows);
+      list.add(maxRows);
 
     boolean present_fetchType = true && (isSetFetchType());
-    builder.append(present_fetchType);
+    list.add(present_fetchType);
     if (present_fetchType)
-      builder.append(fetchType);
+      list.add(fetchType);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TFetchResultsReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TFetchResultsReq typedOther = (TFetchResultsReq)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOrientation()).compareTo(typedOther.isSetOrientation());
+    lastComparison = Boolean.valueOf(isSetOrientation()).compareTo(other.isSetOrientation());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOrientation()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.orientation, typedOther.orientation);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.orientation, other.orientation);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMaxRows()).compareTo(typedOther.isSetMaxRows());
+    lastComparison = Boolean.valueOf(isSetMaxRows()).compareTo(other.isSetMaxRows());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMaxRows()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxRows, typedOther.maxRows);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.maxRows, other.maxRows);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetFetchType()).compareTo(typedOther.isSetFetchType());
+    lastComparison = Boolean.valueOf(isSetFetchType()).compareTo(other.isSetFetchType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFetchType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fetchType, typedOther.fetchType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fetchType, other.fetchType);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -605,7 +609,7 @@ public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsRe
             break;
           case 2: // ORIENTATION
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.orientation = TFetchOrientation.findByValue(iprot.readI32());
+              struct.orientation = org.apache.hive.service.cli.thrift.TFetchOrientation.findByValue(iprot.readI32());
               struct.setOrientationIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -694,7 +698,7 @@ public class TFetchResultsReq implements org.apache.thrift.TBase<TFetchResultsRe
       struct.operationHandle = new TOperationHandle();
       struct.operationHandle.read(iprot);
       struct.setOperationHandleIsSet(true);
-      struct.orientation = TFetchOrientation.findByValue(iprot.readI32());
+      struct.orientation = org.apache.hive.service.cli.thrift.TFetchOrientation.findByValue(iprot.readI32());
       struct.setOrientationIsSet(true);
       struct.maxRows = iprot.readI64();
       struct.setMaxRowsIsSet(true);


[44/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
index d405446..91f8b56 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,6 +7,9 @@
 #include "hive_metastore_types.h"
 
 #include <algorithm>
+#include <ostream>
+
+#include <thrift/TToString.h>
 
 namespace Apache { namespace Hadoop { namespace Hive {
 
@@ -148,6 +151,19 @@ const char* _kResourceTypeNames[] = {
 };
 const std::map<int, const char*> _ResourceType_VALUES_TO_NAMES(::apache::thrift::TEnumIterator(3, _kResourceTypeValues, _kResourceTypeNames), ::apache::thrift::TEnumIterator(-1, NULL, NULL));
 
+
+Version::~Version() throw() {
+}
+
+
+void Version::__set_version(const std::string& val) {
+  this->version = val;
+}
+
+void Version::__set_comments(const std::string& val) {
+  this->comments = val;
+}
+
 const char* Version::ascii_fingerprint = "07A9615F837F7D0A952B595DD3020972";
 const uint8_t Version::binary_fingerprint[16] = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
@@ -201,6 +217,7 @@ uint32_t Version::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Version::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Version");
 
   xfer += oprot->writeFieldBegin("version", ::apache::thrift::protocol::T_STRING, 1);
@@ -213,6 +230,7 @@ uint32_t Version::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -223,6 +241,43 @@ void swap(Version &a, Version &b) {
   swap(a.__isset, b.__isset);
 }
 
+Version::Version(const Version& other0) {
+  version = other0.version;
+  comments = other0.comments;
+  __isset = other0.__isset;
+}
+Version& Version::operator=(const Version& other1) {
+  version = other1.version;
+  comments = other1.comments;
+  __isset = other1.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Version& obj) {
+  using apache::thrift::to_string;
+  out << "Version(";
+  out << "version=" << to_string(obj.version);
+  out << ", " << "comments=" << to_string(obj.comments);
+  out << ")";
+  return out;
+}
+
+
+FieldSchema::~FieldSchema() throw() {
+}
+
+
+void FieldSchema::__set_name(const std::string& val) {
+  this->name = val;
+}
+
+void FieldSchema::__set_type(const std::string& val) {
+  this->type = val;
+}
+
+void FieldSchema::__set_comment(const std::string& val) {
+  this->comment = val;
+}
+
 const char* FieldSchema::ascii_fingerprint = "AB879940BD15B6B25691265F7384B271";
 const uint8_t FieldSchema::binary_fingerprint[16] = {0xAB,0x87,0x99,0x40,0xBD,0x15,0xB6,0xB2,0x56,0x91,0x26,0x5F,0x73,0x84,0xB2,0x71};
 
@@ -284,6 +339,7 @@ uint32_t FieldSchema::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t FieldSchema::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("FieldSchema");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -300,6 +356,7 @@ uint32_t FieldSchema::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -311,6 +368,53 @@ void swap(FieldSchema &a, FieldSchema &b) {
   swap(a.__isset, b.__isset);
 }
 
+FieldSchema::FieldSchema(const FieldSchema& other2) {
+  name = other2.name;
+  type = other2.type;
+  comment = other2.comment;
+  __isset = other2.__isset;
+}
+FieldSchema& FieldSchema::operator=(const FieldSchema& other3) {
+  name = other3.name;
+  type = other3.type;
+  comment = other3.comment;
+  __isset = other3.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const FieldSchema& obj) {
+  using apache::thrift::to_string;
+  out << "FieldSchema(";
+  out << "name=" << to_string(obj.name);
+  out << ", " << "type=" << to_string(obj.type);
+  out << ", " << "comment=" << to_string(obj.comment);
+  out << ")";
+  return out;
+}
+
+
+Type::~Type() throw() {
+}
+
+
+void Type::__set_name(const std::string& val) {
+  this->name = val;
+}
+
+void Type::__set_type1(const std::string& val) {
+  this->type1 = val;
+__isset.type1 = true;
+}
+
+void Type::__set_type2(const std::string& val) {
+  this->type2 = val;
+__isset.type2 = true;
+}
+
+void Type::__set_fields(const std::vector<FieldSchema> & val) {
+  this->fields = val;
+__isset.fields = true;
+}
+
 const char* Type::ascii_fingerprint = "20DF02DE523C27F7066C7BD4D9120842";
 const uint8_t Type::binary_fingerprint[16] = {0x20,0xDF,0x02,0xDE,0x52,0x3C,0x27,0xF7,0x06,0x6C,0x7B,0xD4,0xD9,0x12,0x08,0x42};
 
@@ -362,14 +466,14 @@ uint32_t Type::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->fields.clear();
-            uint32_t _size0;
-            ::apache::thrift::protocol::TType _etype3;
-            xfer += iprot->readListBegin(_etype3, _size0);
-            this->fields.resize(_size0);
-            uint32_t _i4;
-            for (_i4 = 0; _i4 < _size0; ++_i4)
+            uint32_t _size4;
+            ::apache::thrift::protocol::TType _etype7;
+            xfer += iprot->readListBegin(_etype7, _size4);
+            this->fields.resize(_size4);
+            uint32_t _i8;
+            for (_i8 = 0; _i8 < _size4; ++_i8)
             {
-              xfer += this->fields[_i4].read(iprot);
+              xfer += this->fields[_i8].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -392,6 +496,7 @@ uint32_t Type::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Type::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Type");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -412,10 +517,10 @@ uint32_t Type::write(::apache::thrift::protocol::TProtocol* oprot) const {
     xfer += oprot->writeFieldBegin("fields", ::apache::thrift::protocol::T_LIST, 4);
     {
       xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->fields.size()));
-      std::vector<FieldSchema> ::const_iterator _iter5;
-      for (_iter5 = this->fields.begin(); _iter5 != this->fields.end(); ++_iter5)
+      std::vector<FieldSchema> ::const_iterator _iter9;
+      for (_iter9 = this->fields.begin(); _iter9 != this->fields.end(); ++_iter9)
       {
-        xfer += (*_iter5).write(oprot);
+        xfer += (*_iter9).write(oprot);
       }
       xfer += oprot->writeListEnd();
     }
@@ -423,6 +528,7 @@ uint32_t Type::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -435,6 +541,57 @@ void swap(Type &a, Type &b) {
   swap(a.__isset, b.__isset);
 }
 
+Type::Type(const Type& other10) {
+  name = other10.name;
+  type1 = other10.type1;
+  type2 = other10.type2;
+  fields = other10.fields;
+  __isset = other10.__isset;
+}
+Type& Type::operator=(const Type& other11) {
+  name = other11.name;
+  type1 = other11.type1;
+  type2 = other11.type2;
+  fields = other11.fields;
+  __isset = other11.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Type& obj) {
+  using apache::thrift::to_string;
+  out << "Type(";
+  out << "name=" << to_string(obj.name);
+  out << ", " << "type1="; (obj.__isset.type1 ? (out << to_string(obj.type1)) : (out << "<null>"));
+  out << ", " << "type2="; (obj.__isset.type2 ? (out << to_string(obj.type2)) : (out << "<null>"));
+  out << ", " << "fields="; (obj.__isset.fields ? (out << to_string(obj.fields)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+HiveObjectRef::~HiveObjectRef() throw() {
+}
+
+
+void HiveObjectRef::__set_objectType(const HiveObjectType::type val) {
+  this->objectType = val;
+}
+
+void HiveObjectRef::__set_dbName(const std::string& val) {
+  this->dbName = val;
+}
+
+void HiveObjectRef::__set_objectName(const std::string& val) {
+  this->objectName = val;
+}
+
+void HiveObjectRef::__set_partValues(const std::vector<std::string> & val) {
+  this->partValues = val;
+}
+
+void HiveObjectRef::__set_columnName(const std::string& val) {
+  this->columnName = val;
+}
+
 const char* HiveObjectRef::ascii_fingerprint = "205CD8311CF3AA9EC161BAEF8D7C933C";
 const uint8_t HiveObjectRef::binary_fingerprint[16] = {0x20,0x5C,0xD8,0x31,0x1C,0xF3,0xAA,0x9E,0xC1,0x61,0xBA,0xEF,0x8D,0x7C,0x93,0x3C};
 
@@ -460,9 +617,9 @@ uint32_t HiveObjectRef::read(::apache::thrift::protocol::TProtocol* iprot) {
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast6;
-          xfer += iprot->readI32(ecast6);
-          this->objectType = (HiveObjectType::type)ecast6;
+          int32_t ecast12;
+          xfer += iprot->readI32(ecast12);
+          this->objectType = (HiveObjectType::type)ecast12;
           this->__isset.objectType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -488,14 +645,14 @@ uint32_t HiveObjectRef::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->partValues.clear();
-            uint32_t _size7;
-            ::apache::thrift::protocol::TType _etype10;
-            xfer += iprot->readListBegin(_etype10, _size7);
-            this->partValues.resize(_size7);
-            uint32_t _i11;
-            for (_i11 = 0; _i11 < _size7; ++_i11)
+            uint32_t _size13;
+            ::apache::thrift::protocol::TType _etype16;
+            xfer += iprot->readListBegin(_etype16, _size13);
+            this->partValues.resize(_size13);
+            uint32_t _i17;
+            for (_i17 = 0; _i17 < _size13; ++_i17)
             {
-              xfer += iprot->readString(this->partValues[_i11]);
+              xfer += iprot->readString(this->partValues[_i17]);
             }
             xfer += iprot->readListEnd();
           }
@@ -526,6 +683,7 @@ uint32_t HiveObjectRef::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t HiveObjectRef::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("HiveObjectRef");
 
   xfer += oprot->writeFieldBegin("objectType", ::apache::thrift::protocol::T_I32, 1);
@@ -543,10 +701,10 @@ uint32_t HiveObjectRef::write(::apache::thrift::protocol::TProtocol* oprot) cons
   xfer += oprot->writeFieldBegin("partValues", ::apache::thrift::protocol::T_LIST, 4);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->partValues.size()));
-    std::vector<std::string> ::const_iterator _iter12;
-    for (_iter12 = this->partValues.begin(); _iter12 != this->partValues.end(); ++_iter12)
+    std::vector<std::string> ::const_iterator _iter18;
+    for (_iter18 = this->partValues.begin(); _iter18 != this->partValues.end(); ++_iter18)
     {
-      xfer += oprot->writeString((*_iter12));
+      xfer += oprot->writeString((*_iter18));
     }
     xfer += oprot->writeListEnd();
   }
@@ -558,6 +716,7 @@ uint32_t HiveObjectRef::write(::apache::thrift::protocol::TProtocol* oprot) cons
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -571,6 +730,60 @@ void swap(HiveObjectRef &a, HiveObjectRef &b) {
   swap(a.__isset, b.__isset);
 }
 
+HiveObjectRef::HiveObjectRef(const HiveObjectRef& other19) {
+  objectType = other19.objectType;
+  dbName = other19.dbName;
+  objectName = other19.objectName;
+  partValues = other19.partValues;
+  columnName = other19.columnName;
+  __isset = other19.__isset;
+}
+HiveObjectRef& HiveObjectRef::operator=(const HiveObjectRef& other20) {
+  objectType = other20.objectType;
+  dbName = other20.dbName;
+  objectName = other20.objectName;
+  partValues = other20.partValues;
+  columnName = other20.columnName;
+  __isset = other20.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const HiveObjectRef& obj) {
+  using apache::thrift::to_string;
+  out << "HiveObjectRef(";
+  out << "objectType=" << to_string(obj.objectType);
+  out << ", " << "dbName=" << to_string(obj.dbName);
+  out << ", " << "objectName=" << to_string(obj.objectName);
+  out << ", " << "partValues=" << to_string(obj.partValues);
+  out << ", " << "columnName=" << to_string(obj.columnName);
+  out << ")";
+  return out;
+}
+
+
+PrivilegeGrantInfo::~PrivilegeGrantInfo() throw() {
+}
+
+
+void PrivilegeGrantInfo::__set_privilege(const std::string& val) {
+  this->privilege = val;
+}
+
+void PrivilegeGrantInfo::__set_createTime(const int32_t val) {
+  this->createTime = val;
+}
+
+void PrivilegeGrantInfo::__set_grantor(const std::string& val) {
+  this->grantor = val;
+}
+
+void PrivilegeGrantInfo::__set_grantorType(const PrincipalType::type val) {
+  this->grantorType = val;
+}
+
+void PrivilegeGrantInfo::__set_grantOption(const bool val) {
+  this->grantOption = val;
+}
+
 const char* PrivilegeGrantInfo::ascii_fingerprint = "A58923AF7294BE492D6F90E07E8CEE1F";
 const uint8_t PrivilegeGrantInfo::binary_fingerprint[16] = {0xA5,0x89,0x23,0xAF,0x72,0x94,0xBE,0x49,0x2D,0x6F,0x90,0xE0,0x7E,0x8C,0xEE,0x1F};
 
@@ -620,9 +833,9 @@ uint32_t PrivilegeGrantInfo::read(::apache::thrift::protocol::TProtocol* iprot)
         break;
       case 4:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast13;
-          xfer += iprot->readI32(ecast13);
-          this->grantorType = (PrincipalType::type)ecast13;
+          int32_t ecast21;
+          xfer += iprot->readI32(ecast21);
+          this->grantorType = (PrincipalType::type)ecast21;
           this->__isset.grantorType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -650,6 +863,7 @@ uint32_t PrivilegeGrantInfo::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t PrivilegeGrantInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("PrivilegeGrantInfo");
 
   xfer += oprot->writeFieldBegin("privilege", ::apache::thrift::protocol::T_STRING, 1);
@@ -674,6 +888,7 @@ uint32_t PrivilegeGrantInfo::write(::apache::thrift::protocol::TProtocol* oprot)
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -687,6 +902,56 @@ void swap(PrivilegeGrantInfo &a, PrivilegeGrantInfo &b) {
   swap(a.__isset, b.__isset);
 }
 
+PrivilegeGrantInfo::PrivilegeGrantInfo(const PrivilegeGrantInfo& other22) {
+  privilege = other22.privilege;
+  createTime = other22.createTime;
+  grantor = other22.grantor;
+  grantorType = other22.grantorType;
+  grantOption = other22.grantOption;
+  __isset = other22.__isset;
+}
+PrivilegeGrantInfo& PrivilegeGrantInfo::operator=(const PrivilegeGrantInfo& other23) {
+  privilege = other23.privilege;
+  createTime = other23.createTime;
+  grantor = other23.grantor;
+  grantorType = other23.grantorType;
+  grantOption = other23.grantOption;
+  __isset = other23.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const PrivilegeGrantInfo& obj) {
+  using apache::thrift::to_string;
+  out << "PrivilegeGrantInfo(";
+  out << "privilege=" << to_string(obj.privilege);
+  out << ", " << "createTime=" << to_string(obj.createTime);
+  out << ", " << "grantor=" << to_string(obj.grantor);
+  out << ", " << "grantorType=" << to_string(obj.grantorType);
+  out << ", " << "grantOption=" << to_string(obj.grantOption);
+  out << ")";
+  return out;
+}
+
+
+HiveObjectPrivilege::~HiveObjectPrivilege() throw() {
+}
+
+
+void HiveObjectPrivilege::__set_hiveObject(const HiveObjectRef& val) {
+  this->hiveObject = val;
+}
+
+void HiveObjectPrivilege::__set_principalName(const std::string& val) {
+  this->principalName = val;
+}
+
+void HiveObjectPrivilege::__set_principalType(const PrincipalType::type val) {
+  this->principalType = val;
+}
+
+void HiveObjectPrivilege::__set_grantInfo(const PrivilegeGrantInfo& val) {
+  this->grantInfo = val;
+}
+
 const char* HiveObjectPrivilege::ascii_fingerprint = "83D71969B23BD853E29DBA9D43B29AF8";
 const uint8_t HiveObjectPrivilege::binary_fingerprint[16] = {0x83,0xD7,0x19,0x69,0xB2,0x3B,0xD8,0x53,0xE2,0x9D,0xBA,0x9D,0x43,0xB2,0x9A,0xF8};
 
@@ -728,9 +993,9 @@ uint32_t HiveObjectPrivilege::read(::apache::thrift::protocol::TProtocol* iprot)
         break;
       case 3:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast14;
-          xfer += iprot->readI32(ecast14);
-          this->principalType = (PrincipalType::type)ecast14;
+          int32_t ecast24;
+          xfer += iprot->readI32(ecast24);
+          this->principalType = (PrincipalType::type)ecast24;
           this->__isset.principalType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -758,6 +1023,7 @@ uint32_t HiveObjectPrivilege::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t HiveObjectPrivilege::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("HiveObjectPrivilege");
 
   xfer += oprot->writeFieldBegin("hiveObject", ::apache::thrift::protocol::T_STRUCT, 1);
@@ -778,6 +1044,7 @@ uint32_t HiveObjectPrivilege::write(::apache::thrift::protocol::TProtocol* oprot
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -790,6 +1057,41 @@ void swap(HiveObjectPrivilege &a, HiveObjectPrivilege &b) {
   swap(a.__isset, b.__isset);
 }
 
+HiveObjectPrivilege::HiveObjectPrivilege(const HiveObjectPrivilege& other25) {
+  hiveObject = other25.hiveObject;
+  principalName = other25.principalName;
+  principalType = other25.principalType;
+  grantInfo = other25.grantInfo;
+  __isset = other25.__isset;
+}
+HiveObjectPrivilege& HiveObjectPrivilege::operator=(const HiveObjectPrivilege& other26) {
+  hiveObject = other26.hiveObject;
+  principalName = other26.principalName;
+  principalType = other26.principalType;
+  grantInfo = other26.grantInfo;
+  __isset = other26.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const HiveObjectPrivilege& obj) {
+  using apache::thrift::to_string;
+  out << "HiveObjectPrivilege(";
+  out << "hiveObject=" << to_string(obj.hiveObject);
+  out << ", " << "principalName=" << to_string(obj.principalName);
+  out << ", " << "principalType=" << to_string(obj.principalType);
+  out << ", " << "grantInfo=" << to_string(obj.grantInfo);
+  out << ")";
+  return out;
+}
+
+
+PrivilegeBag::~PrivilegeBag() throw() {
+}
+
+
+void PrivilegeBag::__set_privileges(const std::vector<HiveObjectPrivilege> & val) {
+  this->privileges = val;
+}
+
 const char* PrivilegeBag::ascii_fingerprint = "BB89E4701B7B709B046A74C90B1147F2";
 const uint8_t PrivilegeBag::binary_fingerprint[16] = {0xBB,0x89,0xE4,0x70,0x1B,0x7B,0x70,0x9B,0x04,0x6A,0x74,0xC9,0x0B,0x11,0x47,0xF2};
 
@@ -817,14 +1119,14 @@ uint32_t PrivilegeBag::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->privileges.clear();
-            uint32_t _size15;
-            ::apache::thrift::protocol::TType _etype18;
-            xfer += iprot->readListBegin(_etype18, _size15);
-            this->privileges.resize(_size15);
-            uint32_t _i19;
-            for (_i19 = 0; _i19 < _size15; ++_i19)
+            uint32_t _size27;
+            ::apache::thrift::protocol::TType _etype30;
+            xfer += iprot->readListBegin(_etype30, _size27);
+            this->privileges.resize(_size27);
+            uint32_t _i31;
+            for (_i31 = 0; _i31 < _size27; ++_i31)
             {
-              xfer += this->privileges[_i19].read(iprot);
+              xfer += this->privileges[_i31].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -847,15 +1149,16 @@ uint32_t PrivilegeBag::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t PrivilegeBag::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("PrivilegeBag");
 
   xfer += oprot->writeFieldBegin("privileges", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->privileges.size()));
-    std::vector<HiveObjectPrivilege> ::const_iterator _iter20;
-    for (_iter20 = this->privileges.begin(); _iter20 != this->privileges.end(); ++_iter20)
+    std::vector<HiveObjectPrivilege> ::const_iterator _iter32;
+    for (_iter32 = this->privileges.begin(); _iter32 != this->privileges.end(); ++_iter32)
     {
-      xfer += (*_iter20).write(oprot);
+      xfer += (*_iter32).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -863,6 +1166,7 @@ uint32_t PrivilegeBag::write(::apache::thrift::protocol::TProtocol* oprot) const
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -872,6 +1176,40 @@ void swap(PrivilegeBag &a, PrivilegeBag &b) {
   swap(a.__isset, b.__isset);
 }
 
+PrivilegeBag::PrivilegeBag(const PrivilegeBag& other33) {
+  privileges = other33.privileges;
+  __isset = other33.__isset;
+}
+PrivilegeBag& PrivilegeBag::operator=(const PrivilegeBag& other34) {
+  privileges = other34.privileges;
+  __isset = other34.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const PrivilegeBag& obj) {
+  using apache::thrift::to_string;
+  out << "PrivilegeBag(";
+  out << "privileges=" << to_string(obj.privileges);
+  out << ")";
+  return out;
+}
+
+
+PrincipalPrivilegeSet::~PrincipalPrivilegeSet() throw() {
+}
+
+
+void PrincipalPrivilegeSet::__set_userPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
+  this->userPrivileges = val;
+}
+
+void PrincipalPrivilegeSet::__set_groupPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
+  this->groupPrivileges = val;
+}
+
+void PrincipalPrivilegeSet::__set_rolePrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
+  this->rolePrivileges = val;
+}
+
 const char* PrincipalPrivilegeSet::ascii_fingerprint = "08F75D2533906EA87BE34EA640856683";
 const uint8_t PrincipalPrivilegeSet::binary_fingerprint[16] = {0x08,0xF7,0x5D,0x25,0x33,0x90,0x6E,0xA8,0x7B,0xE3,0x4E,0xA6,0x40,0x85,0x66,0x83};
 
@@ -899,26 +1237,26 @@ uint32_t PrincipalPrivilegeSet::read(::apache::thrift::protocol::TProtocol* ipro
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->userPrivileges.clear();
-            uint32_t _size21;
-            ::apache::thrift::protocol::TType _ktype22;
-            ::apache::thrift::protocol::TType _vtype23;
-            xfer += iprot->readMapBegin(_ktype22, _vtype23, _size21);
-            uint32_t _i25;
-            for (_i25 = 0; _i25 < _size21; ++_i25)
+            uint32_t _size35;
+            ::apache::thrift::protocol::TType _ktype36;
+            ::apache::thrift::protocol::TType _vtype37;
+            xfer += iprot->readMapBegin(_ktype36, _vtype37, _size35);
+            uint32_t _i39;
+            for (_i39 = 0; _i39 < _size35; ++_i39)
             {
-              std::string _key26;
-              xfer += iprot->readString(_key26);
-              std::vector<PrivilegeGrantInfo> & _val27 = this->userPrivileges[_key26];
+              std::string _key40;
+              xfer += iprot->readString(_key40);
+              std::vector<PrivilegeGrantInfo> & _val41 = this->userPrivileges[_key40];
               {
-                _val27.clear();
-                uint32_t _size28;
-                ::apache::thrift::protocol::TType _etype31;
-                xfer += iprot->readListBegin(_etype31, _size28);
-                _val27.resize(_size28);
-                uint32_t _i32;
-                for (_i32 = 0; _i32 < _size28; ++_i32)
+                _val41.clear();
+                uint32_t _size42;
+                ::apache::thrift::protocol::TType _etype45;
+                xfer += iprot->readListBegin(_etype45, _size42);
+                _val41.resize(_size42);
+                uint32_t _i46;
+                for (_i46 = 0; _i46 < _size42; ++_i46)
                 {
-                  xfer += _val27[_i32].read(iprot);
+                  xfer += _val41[_i46].read(iprot);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -934,26 +1272,26 @@ uint32_t PrincipalPrivilegeSet::read(::apache::thrift::protocol::TProtocol* ipro
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->groupPrivileges.clear();
-            uint32_t _size33;
-            ::apache::thrift::protocol::TType _ktype34;
-            ::apache::thrift::protocol::TType _vtype35;
-            xfer += iprot->readMapBegin(_ktype34, _vtype35, _size33);
-            uint32_t _i37;
-            for (_i37 = 0; _i37 < _size33; ++_i37)
+            uint32_t _size47;
+            ::apache::thrift::protocol::TType _ktype48;
+            ::apache::thrift::protocol::TType _vtype49;
+            xfer += iprot->readMapBegin(_ktype48, _vtype49, _size47);
+            uint32_t _i51;
+            for (_i51 = 0; _i51 < _size47; ++_i51)
             {
-              std::string _key38;
-              xfer += iprot->readString(_key38);
-              std::vector<PrivilegeGrantInfo> & _val39 = this->groupPrivileges[_key38];
+              std::string _key52;
+              xfer += iprot->readString(_key52);
+              std::vector<PrivilegeGrantInfo> & _val53 = this->groupPrivileges[_key52];
               {
-                _val39.clear();
-                uint32_t _size40;
-                ::apache::thrift::protocol::TType _etype43;
-                xfer += iprot->readListBegin(_etype43, _size40);
-                _val39.resize(_size40);
-                uint32_t _i44;
-                for (_i44 = 0; _i44 < _size40; ++_i44)
+                _val53.clear();
+                uint32_t _size54;
+                ::apache::thrift::protocol::TType _etype57;
+                xfer += iprot->readListBegin(_etype57, _size54);
+                _val53.resize(_size54);
+                uint32_t _i58;
+                for (_i58 = 0; _i58 < _size54; ++_i58)
                 {
-                  xfer += _val39[_i44].read(iprot);
+                  xfer += _val53[_i58].read(iprot);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -969,26 +1307,26 @@ uint32_t PrincipalPrivilegeSet::read(::apache::thrift::protocol::TProtocol* ipro
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->rolePrivileges.clear();
-            uint32_t _size45;
-            ::apache::thrift::protocol::TType _ktype46;
-            ::apache::thrift::protocol::TType _vtype47;
-            xfer += iprot->readMapBegin(_ktype46, _vtype47, _size45);
-            uint32_t _i49;
-            for (_i49 = 0; _i49 < _size45; ++_i49)
+            uint32_t _size59;
+            ::apache::thrift::protocol::TType _ktype60;
+            ::apache::thrift::protocol::TType _vtype61;
+            xfer += iprot->readMapBegin(_ktype60, _vtype61, _size59);
+            uint32_t _i63;
+            for (_i63 = 0; _i63 < _size59; ++_i63)
             {
-              std::string _key50;
-              xfer += iprot->readString(_key50);
-              std::vector<PrivilegeGrantInfo> & _val51 = this->rolePrivileges[_key50];
+              std::string _key64;
+              xfer += iprot->readString(_key64);
+              std::vector<PrivilegeGrantInfo> & _val65 = this->rolePrivileges[_key64];
               {
-                _val51.clear();
-                uint32_t _size52;
-                ::apache::thrift::protocol::TType _etype55;
-                xfer += iprot->readListBegin(_etype55, _size52);
-                _val51.resize(_size52);
-                uint32_t _i56;
-                for (_i56 = 0; _i56 < _size52; ++_i56)
+                _val65.clear();
+                uint32_t _size66;
+                ::apache::thrift::protocol::TType _etype69;
+                xfer += iprot->readListBegin(_etype69, _size66);
+                _val65.resize(_size66);
+                uint32_t _i70;
+                for (_i70 = 0; _i70 < _size66; ++_i70)
                 {
-                  xfer += _val51[_i56].read(iprot);
+                  xfer += _val65[_i70].read(iprot);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -1014,21 +1352,22 @@ uint32_t PrincipalPrivilegeSet::read(::apache::thrift::protocol::TProtocol* ipro
 
 uint32_t PrincipalPrivilegeSet::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("PrincipalPrivilegeSet");
 
   xfer += oprot->writeFieldBegin("userPrivileges", ::apache::thrift::protocol::T_MAP, 1);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->userPrivileges.size()));
-    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter57;
-    for (_iter57 = this->userPrivileges.begin(); _iter57 != this->userPrivileges.end(); ++_iter57)
+    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter71;
+    for (_iter71 = this->userPrivileges.begin(); _iter71 != this->userPrivileges.end(); ++_iter71)
     {
-      xfer += oprot->writeString(_iter57->first);
+      xfer += oprot->writeString(_iter71->first);
       {
-        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter57->second.size()));
-        std::vector<PrivilegeGrantInfo> ::const_iterator _iter58;
-        for (_iter58 = _iter57->second.begin(); _iter58 != _iter57->second.end(); ++_iter58)
+        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter71->second.size()));
+        std::vector<PrivilegeGrantInfo> ::const_iterator _iter72;
+        for (_iter72 = _iter71->second.begin(); _iter72 != _iter71->second.end(); ++_iter72)
         {
-          xfer += (*_iter58).write(oprot);
+          xfer += (*_iter72).write(oprot);
         }
         xfer += oprot->writeListEnd();
       }
@@ -1040,16 +1379,16 @@ uint32_t PrincipalPrivilegeSet::write(::apache::thrift::protocol::TProtocol* opr
   xfer += oprot->writeFieldBegin("groupPrivileges", ::apache::thrift::protocol::T_MAP, 2);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->groupPrivileges.size()));
-    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter59;
-    for (_iter59 = this->groupPrivileges.begin(); _iter59 != this->groupPrivileges.end(); ++_iter59)
+    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter73;
+    for (_iter73 = this->groupPrivileges.begin(); _iter73 != this->groupPrivileges.end(); ++_iter73)
     {
-      xfer += oprot->writeString(_iter59->first);
+      xfer += oprot->writeString(_iter73->first);
       {
-        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter59->second.size()));
-        std::vector<PrivilegeGrantInfo> ::const_iterator _iter60;
-        for (_iter60 = _iter59->second.begin(); _iter60 != _iter59->second.end(); ++_iter60)
+        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter73->second.size()));
+        std::vector<PrivilegeGrantInfo> ::const_iterator _iter74;
+        for (_iter74 = _iter73->second.begin(); _iter74 != _iter73->second.end(); ++_iter74)
         {
-          xfer += (*_iter60).write(oprot);
+          xfer += (*_iter74).write(oprot);
         }
         xfer += oprot->writeListEnd();
       }
@@ -1061,16 +1400,16 @@ uint32_t PrincipalPrivilegeSet::write(::apache::thrift::protocol::TProtocol* opr
   xfer += oprot->writeFieldBegin("rolePrivileges", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->rolePrivileges.size()));
-    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter61;
-    for (_iter61 = this->rolePrivileges.begin(); _iter61 != this->rolePrivileges.end(); ++_iter61)
+    std::map<std::string, std::vector<PrivilegeGrantInfo> > ::const_iterator _iter75;
+    for (_iter75 = this->rolePrivileges.begin(); _iter75 != this->rolePrivileges.end(); ++_iter75)
     {
-      xfer += oprot->writeString(_iter61->first);
+      xfer += oprot->writeString(_iter75->first);
       {
-        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter61->second.size()));
-        std::vector<PrivilegeGrantInfo> ::const_iterator _iter62;
-        for (_iter62 = _iter61->second.begin(); _iter62 != _iter61->second.end(); ++_iter62)
+        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(_iter75->second.size()));
+        std::vector<PrivilegeGrantInfo> ::const_iterator _iter76;
+        for (_iter76 = _iter75->second.begin(); _iter76 != _iter75->second.end(); ++_iter76)
         {
-          xfer += (*_iter62).write(oprot);
+          xfer += (*_iter76).write(oprot);
         }
         xfer += oprot->writeListEnd();
       }
@@ -1081,6 +1420,7 @@ uint32_t PrincipalPrivilegeSet::write(::apache::thrift::protocol::TProtocol* opr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1092,6 +1432,47 @@ void swap(PrincipalPrivilegeSet &a, PrincipalPrivilegeSet &b) {
   swap(a.__isset, b.__isset);
 }
 
+PrincipalPrivilegeSet::PrincipalPrivilegeSet(const PrincipalPrivilegeSet& other77) {
+  userPrivileges = other77.userPrivileges;
+  groupPrivileges = other77.groupPrivileges;
+  rolePrivileges = other77.rolePrivileges;
+  __isset = other77.__isset;
+}
+PrincipalPrivilegeSet& PrincipalPrivilegeSet::operator=(const PrincipalPrivilegeSet& other78) {
+  userPrivileges = other78.userPrivileges;
+  groupPrivileges = other78.groupPrivileges;
+  rolePrivileges = other78.rolePrivileges;
+  __isset = other78.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const PrincipalPrivilegeSet& obj) {
+  using apache::thrift::to_string;
+  out << "PrincipalPrivilegeSet(";
+  out << "userPrivileges=" << to_string(obj.userPrivileges);
+  out << ", " << "groupPrivileges=" << to_string(obj.groupPrivileges);
+  out << ", " << "rolePrivileges=" << to_string(obj.rolePrivileges);
+  out << ")";
+  return out;
+}
+
+
+GrantRevokePrivilegeRequest::~GrantRevokePrivilegeRequest() throw() {
+}
+
+
+void GrantRevokePrivilegeRequest::__set_requestType(const GrantRevokeType::type val) {
+  this->requestType = val;
+}
+
+void GrantRevokePrivilegeRequest::__set_privileges(const PrivilegeBag& val) {
+  this->privileges = val;
+}
+
+void GrantRevokePrivilegeRequest::__set_revokeGrantOption(const bool val) {
+  this->revokeGrantOption = val;
+__isset.revokeGrantOption = true;
+}
+
 const char* GrantRevokePrivilegeRequest::ascii_fingerprint = "DF474A3CB526AD40DC0F2C3702F7AA2C";
 const uint8_t GrantRevokePrivilegeRequest::binary_fingerprint[16] = {0xDF,0x47,0x4A,0x3C,0xB5,0x26,0xAD,0x40,0xDC,0x0F,0x2C,0x37,0x02,0xF7,0xAA,0x2C};
 
@@ -1117,9 +1498,9 @@ uint32_t GrantRevokePrivilegeRequest::read(::apache::thrift::protocol::TProtocol
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast63;
-          xfer += iprot->readI32(ecast63);
-          this->requestType = (GrantRevokeType::type)ecast63;
+          int32_t ecast79;
+          xfer += iprot->readI32(ecast79);
+          this->requestType = (GrantRevokeType::type)ecast79;
           this->__isset.requestType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1155,6 +1536,7 @@ uint32_t GrantRevokePrivilegeRequest::read(::apache::thrift::protocol::TProtocol
 
 uint32_t GrantRevokePrivilegeRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GrantRevokePrivilegeRequest");
 
   xfer += oprot->writeFieldBegin("requestType", ::apache::thrift::protocol::T_I32, 1);
@@ -1172,6 +1554,7 @@ uint32_t GrantRevokePrivilegeRequest::write(::apache::thrift::protocol::TProtoco
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1183,6 +1566,39 @@ void swap(GrantRevokePrivilegeRequest &a, GrantRevokePrivilegeRequest &b) {
   swap(a.__isset, b.__isset);
 }
 
+GrantRevokePrivilegeRequest::GrantRevokePrivilegeRequest(const GrantRevokePrivilegeRequest& other80) {
+  requestType = other80.requestType;
+  privileges = other80.privileges;
+  revokeGrantOption = other80.revokeGrantOption;
+  __isset = other80.__isset;
+}
+GrantRevokePrivilegeRequest& GrantRevokePrivilegeRequest::operator=(const GrantRevokePrivilegeRequest& other81) {
+  requestType = other81.requestType;
+  privileges = other81.privileges;
+  revokeGrantOption = other81.revokeGrantOption;
+  __isset = other81.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GrantRevokePrivilegeRequest& obj) {
+  using apache::thrift::to_string;
+  out << "GrantRevokePrivilegeRequest(";
+  out << "requestType=" << to_string(obj.requestType);
+  out << ", " << "privileges=" << to_string(obj.privileges);
+  out << ", " << "revokeGrantOption="; (obj.__isset.revokeGrantOption ? (out << to_string(obj.revokeGrantOption)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+GrantRevokePrivilegeResponse::~GrantRevokePrivilegeResponse() throw() {
+}
+
+
+void GrantRevokePrivilegeResponse::__set_success(const bool val) {
+  this->success = val;
+__isset.success = true;
+}
+
 const char* GrantRevokePrivilegeResponse::ascii_fingerprint = "BF054652DEF86253C2BEE7D947F167DD";
 const uint8_t GrantRevokePrivilegeResponse::binary_fingerprint[16] = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
@@ -1228,6 +1644,7 @@ uint32_t GrantRevokePrivilegeResponse::read(::apache::thrift::protocol::TProtoco
 
 uint32_t GrantRevokePrivilegeResponse::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GrantRevokePrivilegeResponse");
 
   if (this->__isset.success) {
@@ -1237,6 +1654,7 @@ uint32_t GrantRevokePrivilegeResponse::write(::apache::thrift::protocol::TProtoc
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1246,6 +1664,40 @@ void swap(GrantRevokePrivilegeResponse &a, GrantRevokePrivilegeResponse &b) {
   swap(a.__isset, b.__isset);
 }
 
+GrantRevokePrivilegeResponse::GrantRevokePrivilegeResponse(const GrantRevokePrivilegeResponse& other82) {
+  success = other82.success;
+  __isset = other82.__isset;
+}
+GrantRevokePrivilegeResponse& GrantRevokePrivilegeResponse::operator=(const GrantRevokePrivilegeResponse& other83) {
+  success = other83.success;
+  __isset = other83.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GrantRevokePrivilegeResponse& obj) {
+  using apache::thrift::to_string;
+  out << "GrantRevokePrivilegeResponse(";
+  out << "success="; (obj.__isset.success ? (out << to_string(obj.success)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+Role::~Role() throw() {
+}
+
+
+void Role::__set_roleName(const std::string& val) {
+  this->roleName = val;
+}
+
+void Role::__set_createTime(const int32_t val) {
+  this->createTime = val;
+}
+
+void Role::__set_ownerName(const std::string& val) {
+  this->ownerName = val;
+}
+
 const char* Role::ascii_fingerprint = "70563A0628F75DF9555F4D24690B1E26";
 const uint8_t Role::binary_fingerprint[16] = {0x70,0x56,0x3A,0x06,0x28,0xF7,0x5D,0xF9,0x55,0x5F,0x4D,0x24,0x69,0x0B,0x1E,0x26};
 
@@ -1307,6 +1759,7 @@ uint32_t Role::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Role::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Role");
 
   xfer += oprot->writeFieldBegin("roleName", ::apache::thrift::protocol::T_STRING, 1);
@@ -1323,6 +1776,7 @@ uint32_t Role::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1334,6 +1788,62 @@ void swap(Role &a, Role &b) {
   swap(a.__isset, b.__isset);
 }
 
+Role::Role(const Role& other84) {
+  roleName = other84.roleName;
+  createTime = other84.createTime;
+  ownerName = other84.ownerName;
+  __isset = other84.__isset;
+}
+Role& Role::operator=(const Role& other85) {
+  roleName = other85.roleName;
+  createTime = other85.createTime;
+  ownerName = other85.ownerName;
+  __isset = other85.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Role& obj) {
+  using apache::thrift::to_string;
+  out << "Role(";
+  out << "roleName=" << to_string(obj.roleName);
+  out << ", " << "createTime=" << to_string(obj.createTime);
+  out << ", " << "ownerName=" << to_string(obj.ownerName);
+  out << ")";
+  return out;
+}
+
+
+RolePrincipalGrant::~RolePrincipalGrant() throw() {
+}
+
+
+void RolePrincipalGrant::__set_roleName(const std::string& val) {
+  this->roleName = val;
+}
+
+void RolePrincipalGrant::__set_principalName(const std::string& val) {
+  this->principalName = val;
+}
+
+void RolePrincipalGrant::__set_principalType(const PrincipalType::type val) {
+  this->principalType = val;
+}
+
+void RolePrincipalGrant::__set_grantOption(const bool val) {
+  this->grantOption = val;
+}
+
+void RolePrincipalGrant::__set_grantTime(const int32_t val) {
+  this->grantTime = val;
+}
+
+void RolePrincipalGrant::__set_grantorName(const std::string& val) {
+  this->grantorName = val;
+}
+
+void RolePrincipalGrant::__set_grantorPrincipalType(const PrincipalType::type val) {
+  this->grantorPrincipalType = val;
+}
+
 const char* RolePrincipalGrant::ascii_fingerprint = "899BA3F6214DD1B79D27206BA857C772";
 const uint8_t RolePrincipalGrant::binary_fingerprint[16] = {0x89,0x9B,0xA3,0xF6,0x21,0x4D,0xD1,0xB7,0x9D,0x27,0x20,0x6B,0xA8,0x57,0xC7,0x72};
 
@@ -1375,9 +1885,9 @@ uint32_t RolePrincipalGrant::read(::apache::thrift::protocol::TProtocol* iprot)
         break;
       case 3:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast64;
-          xfer += iprot->readI32(ecast64);
-          this->principalType = (PrincipalType::type)ecast64;
+          int32_t ecast86;
+          xfer += iprot->readI32(ecast86);
+          this->principalType = (PrincipalType::type)ecast86;
           this->__isset.principalType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1409,9 +1919,9 @@ uint32_t RolePrincipalGrant::read(::apache::thrift::protocol::TProtocol* iprot)
         break;
       case 7:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast65;
-          xfer += iprot->readI32(ecast65);
-          this->grantorPrincipalType = (PrincipalType::type)ecast65;
+          int32_t ecast87;
+          xfer += iprot->readI32(ecast87);
+          this->grantorPrincipalType = (PrincipalType::type)ecast87;
           this->__isset.grantorPrincipalType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1431,6 +1941,7 @@ uint32_t RolePrincipalGrant::read(::apache::thrift::protocol::TProtocol* iprot)
 
 uint32_t RolePrincipalGrant::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("RolePrincipalGrant");
 
   xfer += oprot->writeFieldBegin("roleName", ::apache::thrift::protocol::T_STRING, 1);
@@ -1463,6 +1974,7 @@ uint32_t RolePrincipalGrant::write(::apache::thrift::protocol::TProtocol* oprot)
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1478,6 +1990,54 @@ void swap(RolePrincipalGrant &a, RolePrincipalGrant &b) {
   swap(a.__isset, b.__isset);
 }
 
+RolePrincipalGrant::RolePrincipalGrant(const RolePrincipalGrant& other88) {
+  roleName = other88.roleName;
+  principalName = other88.principalName;
+  principalType = other88.principalType;
+  grantOption = other88.grantOption;
+  grantTime = other88.grantTime;
+  grantorName = other88.grantorName;
+  grantorPrincipalType = other88.grantorPrincipalType;
+  __isset = other88.__isset;
+}
+RolePrincipalGrant& RolePrincipalGrant::operator=(const RolePrincipalGrant& other89) {
+  roleName = other89.roleName;
+  principalName = other89.principalName;
+  principalType = other89.principalType;
+  grantOption = other89.grantOption;
+  grantTime = other89.grantTime;
+  grantorName = other89.grantorName;
+  grantorPrincipalType = other89.grantorPrincipalType;
+  __isset = other89.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const RolePrincipalGrant& obj) {
+  using apache::thrift::to_string;
+  out << "RolePrincipalGrant(";
+  out << "roleName=" << to_string(obj.roleName);
+  out << ", " << "principalName=" << to_string(obj.principalName);
+  out << ", " << "principalType=" << to_string(obj.principalType);
+  out << ", " << "grantOption=" << to_string(obj.grantOption);
+  out << ", " << "grantTime=" << to_string(obj.grantTime);
+  out << ", " << "grantorName=" << to_string(obj.grantorName);
+  out << ", " << "grantorPrincipalType=" << to_string(obj.grantorPrincipalType);
+  out << ")";
+  return out;
+}
+
+
+GetRoleGrantsForPrincipalRequest::~GetRoleGrantsForPrincipalRequest() throw() {
+}
+
+
+void GetRoleGrantsForPrincipalRequest::__set_principal_name(const std::string& val) {
+  this->principal_name = val;
+}
+
+void GetRoleGrantsForPrincipalRequest::__set_principal_type(const PrincipalType::type val) {
+  this->principal_type = val;
+}
+
 const char* GetRoleGrantsForPrincipalRequest::ascii_fingerprint = "D6FD826D949221396F4FFC3ECCD3D192";
 const uint8_t GetRoleGrantsForPrincipalRequest::binary_fingerprint[16] = {0xD6,0xFD,0x82,0x6D,0x94,0x92,0x21,0x39,0x6F,0x4F,0xFC,0x3E,0xCC,0xD3,0xD1,0x92};
 
@@ -1513,9 +2073,9 @@ uint32_t GetRoleGrantsForPrincipalRequest::read(::apache::thrift::protocol::TPro
         break;
       case 2:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast66;
-          xfer += iprot->readI32(ecast66);
-          this->principal_type = (PrincipalType::type)ecast66;
+          int32_t ecast90;
+          xfer += iprot->readI32(ecast90);
+          this->principal_type = (PrincipalType::type)ecast90;
           isset_principal_type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1539,6 +2099,7 @@ uint32_t GetRoleGrantsForPrincipalRequest::read(::apache::thrift::protocol::TPro
 
 uint32_t GetRoleGrantsForPrincipalRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GetRoleGrantsForPrincipalRequest");
 
   xfer += oprot->writeFieldBegin("principal_name", ::apache::thrift::protocol::T_STRING, 1);
@@ -1551,6 +2112,7 @@ uint32_t GetRoleGrantsForPrincipalRequest::write(::apache::thrift::protocol::TPr
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1560,6 +2122,33 @@ void swap(GetRoleGrantsForPrincipalRequest &a, GetRoleGrantsForPrincipalRequest
   swap(a.principal_type, b.principal_type);
 }
 
+GetRoleGrantsForPrincipalRequest::GetRoleGrantsForPrincipalRequest(const GetRoleGrantsForPrincipalRequest& other91) {
+  principal_name = other91.principal_name;
+  principal_type = other91.principal_type;
+}
+GetRoleGrantsForPrincipalRequest& GetRoleGrantsForPrincipalRequest::operator=(const GetRoleGrantsForPrincipalRequest& other92) {
+  principal_name = other92.principal_name;
+  principal_type = other92.principal_type;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GetRoleGrantsForPrincipalRequest& obj) {
+  using apache::thrift::to_string;
+  out << "GetRoleGrantsForPrincipalRequest(";
+  out << "principal_name=" << to_string(obj.principal_name);
+  out << ", " << "principal_type=" << to_string(obj.principal_type);
+  out << ")";
+  return out;
+}
+
+
+GetRoleGrantsForPrincipalResponse::~GetRoleGrantsForPrincipalResponse() throw() {
+}
+
+
+void GetRoleGrantsForPrincipalResponse::__set_principalGrants(const std::vector<RolePrincipalGrant> & val) {
+  this->principalGrants = val;
+}
+
 const char* GetRoleGrantsForPrincipalResponse::ascii_fingerprint = "5926B4B3541A62E17663820C7E3BE690";
 const uint8_t GetRoleGrantsForPrincipalResponse::binary_fingerprint[16] = {0x59,0x26,0xB4,0xB3,0x54,0x1A,0x62,0xE1,0x76,0x63,0x82,0x0C,0x7E,0x3B,0xE6,0x90};
 
@@ -1588,14 +2177,14 @@ uint32_t GetRoleGrantsForPrincipalResponse::read(::apache::thrift::protocol::TPr
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->principalGrants.clear();
-            uint32_t _size67;
-            ::apache::thrift::protocol::TType _etype70;
-            xfer += iprot->readListBegin(_etype70, _size67);
-            this->principalGrants.resize(_size67);
-            uint32_t _i71;
-            for (_i71 = 0; _i71 < _size67; ++_i71)
+            uint32_t _size93;
+            ::apache::thrift::protocol::TType _etype96;
+            xfer += iprot->readListBegin(_etype96, _size93);
+            this->principalGrants.resize(_size93);
+            uint32_t _i97;
+            for (_i97 = 0; _i97 < _size93; ++_i97)
             {
-              xfer += this->principalGrants[_i71].read(iprot);
+              xfer += this->principalGrants[_i97].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1620,15 +2209,16 @@ uint32_t GetRoleGrantsForPrincipalResponse::read(::apache::thrift::protocol::TPr
 
 uint32_t GetRoleGrantsForPrincipalResponse::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GetRoleGrantsForPrincipalResponse");
 
   xfer += oprot->writeFieldBegin("principalGrants", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->principalGrants.size()));
-    std::vector<RolePrincipalGrant> ::const_iterator _iter72;
-    for (_iter72 = this->principalGrants.begin(); _iter72 != this->principalGrants.end(); ++_iter72)
+    std::vector<RolePrincipalGrant> ::const_iterator _iter98;
+    for (_iter98 = this->principalGrants.begin(); _iter98 != this->principalGrants.end(); ++_iter98)
     {
-      xfer += (*_iter72).write(oprot);
+      xfer += (*_iter98).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1636,6 +2226,7 @@ uint32_t GetRoleGrantsForPrincipalResponse::write(::apache::thrift::protocol::TP
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1644,6 +2235,30 @@ void swap(GetRoleGrantsForPrincipalResponse &a, GetRoleGrantsForPrincipalRespons
   swap(a.principalGrants, b.principalGrants);
 }
 
+GetRoleGrantsForPrincipalResponse::GetRoleGrantsForPrincipalResponse(const GetRoleGrantsForPrincipalResponse& other99) {
+  principalGrants = other99.principalGrants;
+}
+GetRoleGrantsForPrincipalResponse& GetRoleGrantsForPrincipalResponse::operator=(const GetRoleGrantsForPrincipalResponse& other100) {
+  principalGrants = other100.principalGrants;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GetRoleGrantsForPrincipalResponse& obj) {
+  using apache::thrift::to_string;
+  out << "GetRoleGrantsForPrincipalResponse(";
+  out << "principalGrants=" << to_string(obj.principalGrants);
+  out << ")";
+  return out;
+}
+
+
+GetPrincipalsInRoleRequest::~GetPrincipalsInRoleRequest() throw() {
+}
+
+
+void GetPrincipalsInRoleRequest::__set_roleName(const std::string& val) {
+  this->roleName = val;
+}
+
 const char* GetPrincipalsInRoleRequest::ascii_fingerprint = "EFB929595D312AC8F305D5A794CFEDA1";
 const uint8_t GetPrincipalsInRoleRequest::binary_fingerprint[16] = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
@@ -1692,6 +2307,7 @@ uint32_t GetPrincipalsInRoleRequest::read(::apache::thrift::protocol::TProtocol*
 
 uint32_t GetPrincipalsInRoleRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GetPrincipalsInRoleRequest");
 
   xfer += oprot->writeFieldBegin("roleName", ::apache::thrift::protocol::T_STRING, 1);
@@ -1700,6 +2316,7 @@ uint32_t GetPrincipalsInRoleRequest::write(::apache::thrift::protocol::TProtocol
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1708,6 +2325,30 @@ void swap(GetPrincipalsInRoleRequest &a, GetPrincipalsInRoleRequest &b) {
   swap(a.roleName, b.roleName);
 }
 
+GetPrincipalsInRoleRequest::GetPrincipalsInRoleRequest(const GetPrincipalsInRoleRequest& other101) {
+  roleName = other101.roleName;
+}
+GetPrincipalsInRoleRequest& GetPrincipalsInRoleRequest::operator=(const GetPrincipalsInRoleRequest& other102) {
+  roleName = other102.roleName;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GetPrincipalsInRoleRequest& obj) {
+  using apache::thrift::to_string;
+  out << "GetPrincipalsInRoleRequest(";
+  out << "roleName=" << to_string(obj.roleName);
+  out << ")";
+  return out;
+}
+
+
+GetPrincipalsInRoleResponse::~GetPrincipalsInRoleResponse() throw() {
+}
+
+
+void GetPrincipalsInRoleResponse::__set_principalGrants(const std::vector<RolePrincipalGrant> & val) {
+  this->principalGrants = val;
+}
+
 const char* GetPrincipalsInRoleResponse::ascii_fingerprint = "5926B4B3541A62E17663820C7E3BE690";
 const uint8_t GetPrincipalsInRoleResponse::binary_fingerprint[16] = {0x59,0x26,0xB4,0xB3,0x54,0x1A,0x62,0xE1,0x76,0x63,0x82,0x0C,0x7E,0x3B,0xE6,0x90};
 
@@ -1736,14 +2377,14 @@ uint32_t GetPrincipalsInRoleResponse::read(::apache::thrift::protocol::TProtocol
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->principalGrants.clear();
-            uint32_t _size73;
-            ::apache::thrift::protocol::TType _etype76;
-            xfer += iprot->readListBegin(_etype76, _size73);
-            this->principalGrants.resize(_size73);
-            uint32_t _i77;
-            for (_i77 = 0; _i77 < _size73; ++_i77)
+            uint32_t _size103;
+            ::apache::thrift::protocol::TType _etype106;
+            xfer += iprot->readListBegin(_etype106, _size103);
+            this->principalGrants.resize(_size103);
+            uint32_t _i107;
+            for (_i107 = 0; _i107 < _size103; ++_i107)
             {
-              xfer += this->principalGrants[_i77].read(iprot);
+              xfer += this->principalGrants[_i107].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -1768,15 +2409,16 @@ uint32_t GetPrincipalsInRoleResponse::read(::apache::thrift::protocol::TProtocol
 
 uint32_t GetPrincipalsInRoleResponse::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GetPrincipalsInRoleResponse");
 
   xfer += oprot->writeFieldBegin("principalGrants", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->principalGrants.size()));
-    std::vector<RolePrincipalGrant> ::const_iterator _iter78;
-    for (_iter78 = this->principalGrants.begin(); _iter78 != this->principalGrants.end(); ++_iter78)
+    std::vector<RolePrincipalGrant> ::const_iterator _iter108;
+    for (_iter108 = this->principalGrants.begin(); _iter108 != this->principalGrants.end(); ++_iter108)
     {
-      xfer += (*_iter78).write(oprot);
+      xfer += (*_iter108).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1784,6 +2426,7 @@ uint32_t GetPrincipalsInRoleResponse::write(::apache::thrift::protocol::TProtoco
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1792,6 +2435,57 @@ void swap(GetPrincipalsInRoleResponse &a, GetPrincipalsInRoleResponse &b) {
   swap(a.principalGrants, b.principalGrants);
 }
 
+GetPrincipalsInRoleResponse::GetPrincipalsInRoleResponse(const GetPrincipalsInRoleResponse& other109) {
+  principalGrants = other109.principalGrants;
+}
+GetPrincipalsInRoleResponse& GetPrincipalsInRoleResponse::operator=(const GetPrincipalsInRoleResponse& other110) {
+  principalGrants = other110.principalGrants;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GetPrincipalsInRoleResponse& obj) {
+  using apache::thrift::to_string;
+  out << "GetPrincipalsInRoleResponse(";
+  out << "principalGrants=" << to_string(obj.principalGrants);
+  out << ")";
+  return out;
+}
+
+
+GrantRevokeRoleRequest::~GrantRevokeRoleRequest() throw() {
+}
+
+
+void GrantRevokeRoleRequest::__set_requestType(const GrantRevokeType::type val) {
+  this->requestType = val;
+}
+
+void GrantRevokeRoleRequest::__set_roleName(const std::string& val) {
+  this->roleName = val;
+}
+
+void GrantRevokeRoleRequest::__set_principalName(const std::string& val) {
+  this->principalName = val;
+}
+
+void GrantRevokeRoleRequest::__set_principalType(const PrincipalType::type val) {
+  this->principalType = val;
+}
+
+void GrantRevokeRoleRequest::__set_grantor(const std::string& val) {
+  this->grantor = val;
+__isset.grantor = true;
+}
+
+void GrantRevokeRoleRequest::__set_grantorType(const PrincipalType::type val) {
+  this->grantorType = val;
+__isset.grantorType = true;
+}
+
+void GrantRevokeRoleRequest::__set_grantOption(const bool val) {
+  this->grantOption = val;
+__isset.grantOption = true;
+}
+
 const char* GrantRevokeRoleRequest::ascii_fingerprint = "907DEA796F2BA7AF76DC2566E75FAEE7";
 const uint8_t GrantRevokeRoleRequest::binary_fingerprint[16] = {0x90,0x7D,0xEA,0x79,0x6F,0x2B,0xA7,0xAF,0x76,0xDC,0x25,0x66,0xE7,0x5F,0xAE,0xE7};
 
@@ -1817,9 +2511,9 @@ uint32_t GrantRevokeRoleRequest::read(::apache::thrift::protocol::TProtocol* ipr
     {
       case 1:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast79;
-          xfer += iprot->readI32(ecast79);
-          this->requestType = (GrantRevokeType::type)ecast79;
+          int32_t ecast111;
+          xfer += iprot->readI32(ecast111);
+          this->requestType = (GrantRevokeType::type)ecast111;
           this->__isset.requestType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1843,9 +2537,9 @@ uint32_t GrantRevokeRoleRequest::read(::apache::thrift::protocol::TProtocol* ipr
         break;
       case 4:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast80;
-          xfer += iprot->readI32(ecast80);
-          this->principalType = (PrincipalType::type)ecast80;
+          int32_t ecast112;
+          xfer += iprot->readI32(ecast112);
+          this->principalType = (PrincipalType::type)ecast112;
           this->__isset.principalType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1861,9 +2555,9 @@ uint32_t GrantRevokeRoleRequest::read(::apache::thrift::protocol::TProtocol* ipr
         break;
       case 6:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast81;
-          xfer += iprot->readI32(ecast81);
-          this->grantorType = (PrincipalType::type)ecast81;
+          int32_t ecast113;
+          xfer += iprot->readI32(ecast113);
+          this->grantorType = (PrincipalType::type)ecast113;
           this->__isset.grantorType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -1891,6 +2585,7 @@ uint32_t GrantRevokeRoleRequest::read(::apache::thrift::protocol::TProtocol* ipr
 
 uint32_t GrantRevokeRoleRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GrantRevokeRoleRequest");
 
   xfer += oprot->writeFieldBegin("requestType", ::apache::thrift::protocol::T_I32, 1);
@@ -1926,6 +2621,7 @@ uint32_t GrantRevokeRoleRequest::write(::apache::thrift::protocol::TProtocol* op
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -1941,6 +2637,51 @@ void swap(GrantRevokeRoleRequest &a, GrantRevokeRoleRequest &b) {
   swap(a.__isset, b.__isset);
 }
 
+GrantRevokeRoleRequest::GrantRevokeRoleRequest(const GrantRevokeRoleRequest& other114) {
+  requestType = other114.requestType;
+  roleName = other114.roleName;
+  principalName = other114.principalName;
+  principalType = other114.principalType;
+  grantor = other114.grantor;
+  grantorType = other114.grantorType;
+  grantOption = other114.grantOption;
+  __isset = other114.__isset;
+}
+GrantRevokeRoleRequest& GrantRevokeRoleRequest::operator=(const GrantRevokeRoleRequest& other115) {
+  requestType = other115.requestType;
+  roleName = other115.roleName;
+  principalName = other115.principalName;
+  principalType = other115.principalType;
+  grantor = other115.grantor;
+  grantorType = other115.grantorType;
+  grantOption = other115.grantOption;
+  __isset = other115.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GrantRevokeRoleRequest& obj) {
+  using apache::thrift::to_string;
+  out << "GrantRevokeRoleRequest(";
+  out << "requestType=" << to_string(obj.requestType);
+  out << ", " << "roleName=" << to_string(obj.roleName);
+  out << ", " << "principalName=" << to_string(obj.principalName);
+  out << ", " << "principalType=" << to_string(obj.principalType);
+  out << ", " << "grantor="; (obj.__isset.grantor ? (out << to_string(obj.grantor)) : (out << "<null>"));
+  out << ", " << "grantorType="; (obj.__isset.grantorType ? (out << to_string(obj.grantorType)) : (out << "<null>"));
+  out << ", " << "grantOption="; (obj.__isset.grantOption ? (out << to_string(obj.grantOption)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+GrantRevokeRoleResponse::~GrantRevokeRoleResponse() throw() {
+}
+
+
+void GrantRevokeRoleResponse::__set_success(const bool val) {
+  this->success = val;
+__isset.success = true;
+}
+
 const char* GrantRevokeRoleResponse::ascii_fingerprint = "BF054652DEF86253C2BEE7D947F167DD";
 const uint8_t GrantRevokeRoleResponse::binary_fingerprint[16] = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
@@ -1986,6 +2727,7 @@ uint32_t GrantRevokeRoleResponse::read(::apache::thrift::protocol::TProtocol* ip
 
 uint32_t GrantRevokeRoleResponse::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("GrantRevokeRoleResponse");
 
   if (this->__isset.success) {
@@ -1995,6 +2737,7 @@ uint32_t GrantRevokeRoleResponse::write(::apache::thrift::protocol::TProtocol* o
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2004,7 +2747,60 @@ void swap(GrantRevokeRoleResponse &a, GrantRevokeRoleResponse &b) {
   swap(a.__isset, b.__isset);
 }
 
-const char* Database::ascii_fingerprint = "553495CAE243A1C583D5C3DD990AED53";
+GrantRevokeRoleResponse::GrantRevokeRoleResponse(const GrantRevokeRoleResponse& other116) {
+  success = other116.success;
+  __isset = other116.__isset;
+}
+GrantRevokeRoleResponse& GrantRevokeRoleResponse::operator=(const GrantRevokeRoleResponse& other117) {
+  success = other117.success;
+  __isset = other117.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const GrantRevokeRoleResponse& obj) {
+  using apache::thrift::to_string;
+  out << "GrantRevokeRoleResponse(";
+  out << "success="; (obj.__isset.success ? (out << to_string(obj.success)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+Database::~Database() throw() {
+}
+
+
+void Database::__set_name(const std::string& val) {
+  this->name = val;
+}
+
+void Database::__set_description(const std::string& val) {
+  this->description = val;
+}
+
+void Database::__set_locationUri(const std::string& val) {
+  this->locationUri = val;
+}
+
+void Database::__set_parameters(const std::map<std::string, std::string> & val) {
+  this->parameters = val;
+}
+
+void Database::__set_privileges(const PrincipalPrivilegeSet& val) {
+  this->privileges = val;
+__isset.privileges = true;
+}
+
+void Database::__set_ownerName(const std::string& val) {
+  this->ownerName = val;
+__isset.ownerName = true;
+}
+
+void Database::__set_ownerType(const PrincipalType::type val) {
+  this->ownerType = val;
+__isset.ownerType = true;
+}
+
+const char* Database::ascii_fingerprint = "553495CAE243A1C583D5C3DD990AED53";
 const uint8_t Database::binary_fingerprint[16] = {0x55,0x34,0x95,0xCA,0xE2,0x43,0xA1,0xC5,0x83,0xD5,0xC3,0xDD,0x99,0x0A,0xED,0x53};
 
 uint32_t Database::read(::apache::thrift::protocol::TProtocol* iprot) {
@@ -2055,17 +2851,17 @@ uint32_t Database::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->parameters.clear();
-            uint32_t _size82;
-            ::apache::thrift::protocol::TType _ktype83;
-            ::apache::thrift::protocol::TType _vtype84;
-            xfer += iprot->readMapBegin(_ktype83, _vtype84, _size82);
-            uint32_t _i86;
-            for (_i86 = 0; _i86 < _size82; ++_i86)
+            uint32_t _size118;
+            ::apache::thrift::protocol::TType _ktype119;
+            ::apache::thrift::protocol::TType _vtype120;
+            xfer += iprot->readMapBegin(_ktype119, _vtype120, _size118);
+            uint32_t _i122;
+            for (_i122 = 0; _i122 < _size118; ++_i122)
             {
-              std::string _key87;
-              xfer += iprot->readString(_key87);
-              std::string& _val88 = this->parameters[_key87];
-              xfer += iprot->readString(_val88);
+              std::string _key123;
+              xfer += iprot->readString(_key123);
+              std::string& _val124 = this->parameters[_key123];
+              xfer += iprot->readString(_val124);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2092,9 +2888,9 @@ uint32_t Database::read(::apache::thrift::protocol::TProtocol* iprot) {
         break;
       case 7:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast89;
-          xfer += iprot->readI32(ecast89);
-          this->ownerType = (PrincipalType::type)ecast89;
+          int32_t ecast125;
+          xfer += iprot->readI32(ecast125);
+          this->ownerType = (PrincipalType::type)ecast125;
           this->__isset.ownerType = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -2114,6 +2910,7 @@ uint32_t Database::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Database::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Database");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2131,11 +2928,11 @@ uint32_t Database::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("parameters", ::apache::thrift::protocol::T_MAP, 4);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->parameters.size()));
-    std::map<std::string, std::string> ::const_iterator _iter90;
-    for (_iter90 = this->parameters.begin(); _iter90 != this->parameters.end(); ++_iter90)
+    std::map<std::string, std::string> ::const_iterator _iter126;
+    for (_iter126 = this->parameters.begin(); _iter126 != this->parameters.end(); ++_iter126)
     {
-      xfer += oprot->writeString(_iter90->first);
-      xfer += oprot->writeString(_iter90->second);
+      xfer += oprot->writeString(_iter126->first);
+      xfer += oprot->writeString(_iter126->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -2158,6 +2955,7 @@ uint32_t Database::write(::apache::thrift::protocol::TProtocol* oprot) const {
   }
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2173,6 +2971,58 @@ void swap(Database &a, Database &b) {
   swap(a.__isset, b.__isset);
 }
 
+Database::Database(const Database& other127) {
+  name = other127.name;
+  description = other127.description;
+  locationUri = other127.locationUri;
+  parameters = other127.parameters;
+  privileges = other127.privileges;
+  ownerName = other127.ownerName;
+  ownerType = other127.ownerType;
+  __isset = other127.__isset;
+}
+Database& Database::operator=(const Database& other128) {
+  name = other128.name;
+  description = other128.description;
+  locationUri = other128.locationUri;
+  parameters = other128.parameters;
+  privileges = other128.privileges;
+  ownerName = other128.ownerName;
+  ownerType = other128.ownerType;
+  __isset = other128.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Database& obj) {
+  using apache::thrift::to_string;
+  out << "Database(";
+  out << "name=" << to_string(obj.name);
+  out << ", " << "description=" << to_string(obj.description);
+  out << ", " << "locationUri=" << to_string(obj.locationUri);
+  out << ", " << "parameters=" << to_string(obj.parameters);
+  out << ", " << "privileges="; (obj.__isset.privileges ? (out << to_string(obj.privileges)) : (out << "<null>"));
+  out << ", " << "ownerName="; (obj.__isset.ownerName ? (out << to_string(obj.ownerName)) : (out << "<null>"));
+  out << ", " << "ownerType="; (obj.__isset.ownerType ? (out << to_string(obj.ownerType)) : (out << "<null>"));
+  out << ")";
+  return out;
+}
+
+
+SerDeInfo::~SerDeInfo() throw() {
+}
+
+
+void SerDeInfo::__set_name(const std::string& val) {
+  this->name = val;
+}
+
+void SerDeInfo::__set_serializationLib(const std::string& val) {
+  this->serializationLib = val;
+}
+
+void SerDeInfo::__set_parameters(const std::map<std::string, std::string> & val) {
+  this->parameters = val;
+}
+
 const char* SerDeInfo::ascii_fingerprint = "B1021C32A35A2AEFCD2F57A5424159A7";
 const uint8_t SerDeInfo::binary_fingerprint[16] = {0xB1,0x02,0x1C,0x32,0xA3,0x5A,0x2A,0xEF,0xCD,0x2F,0x57,0xA5,0x42,0x41,0x59,0xA7};
 
@@ -2216,17 +3066,17 @@ uint32_t SerDeInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->parameters.clear();
-            uint32_t _size91;
-            ::apache::thrift::protocol::TType _ktype92;
-            ::apache::thrift::protocol::TType _vtype93;
-            xfer += iprot->readMapBegin(_ktype92, _vtype93, _size91);
-            uint32_t _i95;
-            for (_i95 = 0; _i95 < _size91; ++_i95)
+            uint32_t _size129;
+            ::apache::thrift::protocol::TType _ktype130;
+            ::apache::thrift::protocol::TType _vtype131;
+            xfer += iprot->readMapBegin(_ktype130, _vtype131, _size129);
+            uint32_t _i133;
+            for (_i133 = 0; _i133 < _size129; ++_i133)
             {
-              std::string _key96;
-              xfer += iprot->readString(_key96);
-              std::string& _val97 = this->parameters[_key96];
-              xfer += iprot->readString(_val97);
+              std::string _key134;
+              xfer += iprot->readString(_key134);
+              std::string& _val135 = this->parameters[_key134];
+              xfer += iprot->readString(_val135);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2249,6 +3099,7 @@ uint32_t SerDeInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t SerDeInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("SerDeInfo");
 
   xfer += oprot->writeFieldBegin("name", ::apache::thrift::protocol::T_STRING, 1);
@@ -2262,11 +3113,11 @@ uint32_t SerDeInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("parameters", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_STRING, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->parameters.size()));
-    std::map<std::string, std::string> ::const_iterator _iter98;
-    for (_iter98 = this->parameters.begin(); _iter98 != this->parameters.end(); ++_iter98)
+    std::map<std::string, std::string> ::const_iterator _iter136;
+    for (_iter136 = this->parameters.begin(); _iter136 != this->parameters.end(); ++_iter136)
     {
-      xfer += oprot->writeString(_iter98->first);
-      xfer += oprot->writeString(_iter98->second);
+      xfer += oprot->writeString(_iter136->first);
+      xfer += oprot->writeString(_iter136->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -2274,6 +3125,7 @@ uint32_t SerDeInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2285,6 +3137,42 @@ void swap(SerDeInfo &a, SerDeInfo &b) {
   swap(a.__isset, b.__isset);
 }
 
+SerDeInfo::SerDeInfo(const SerDeInfo& other137) {
+  name = other137.name;
+  serializationLib = other137.serializationLib;
+  parameters = other137.parameters;
+  __isset = other137.__isset;
+}
+SerDeInfo& SerDeInfo::operator=(const SerDeInfo& other138) {
+  name = other138.name;
+  serializationLib = other138.serializationLib;
+  parameters = other138.parameters;
+  __isset = other138.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const SerDeInfo& obj) {
+  using apache::thrift::to_string;
+  out << "SerDeInfo(";
+  out << "name=" << to_string(obj.name);
+  out << ", " << "serializationLib=" << to_string(obj.serializationLib);
+  out << ", " << "parameters=" << to_string(obj.parameters);
+  out << ")";
+  return out;
+}
+
+
+Order::~Order() throw() {
+}
+
+
+void Order::__set_col(const std::string& val) {
+  this->col = val;
+}
+
+void Order::__set_order(const int32_t val) {
+  this->order = val;
+}
+
 const char* Order::ascii_fingerprint = "EEBC915CE44901401D881E6091423036";
 const uint8_t Order::binary_fingerprint[16] = {0xEE,0xBC,0x91,0x5C,0xE4,0x49,0x01,0x40,0x1D,0x88,0x1E,0x60,0x91,0x42,0x30,0x36};
 
@@ -2338,6 +3226,7 @@ uint32_t Order::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t Order::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("Order");
 
   xfer += oprot->writeFieldBegin("col", ::apache::thrift::protocol::T_STRING, 1);
@@ -2350,6 +3239,7 @@ uint32_t Order::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2360,6 +3250,43 @@ void swap(Order &a, Order &b) {
   swap(a.__isset, b.__isset);
 }
 
+Order::Order(const Order& other139) {
+  col = other139.col;
+  order = other139.order;
+  __isset = other139.__isset;
+}
+Order& Order::operator=(const Order& other140) {
+  col = other140.col;
+  order = other140.order;
+  __isset = other140.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const Order& obj) {
+  using apache::thrift::to_string;
+  out << "Order(";
+  out << "col=" << to_string(obj.col);
+  out << ", " << "order=" << to_string(obj.order);
+  out << ")";
+  return out;
+}
+
+
+SkewedInfo::~SkewedInfo() throw() {
+}
+
+
+void SkewedInfo::__set_skewedColNames(const std::vector<std::string> & val) {
+  this->skewedColNames = val;
+}
+
+void SkewedInfo::__set_skewedColValues(const std::vector<std::vector<std::string> > & val) {
+  this->skewedColValues = val;
+}
+
+void SkewedInfo::__set_skewedColValueLocationMaps(const std::map<std::vector<std::string> , std::string> & val) {
+  this->skewedColValueLocationMaps = val;
+}
+
 const char* SkewedInfo::ascii_fingerprint = "4BF2ED84BC3C3EB297A2AE2FA8427EB1";
 const uint8_t SkewedInfo::binary_fingerprint[16] = {0x4B,0xF2,0xED,0x84,0xBC,0x3C,0x3E,0xB2,0x97,0xA2,0xAE,0x2F,0xA8,0x42,0x7E,0xB1};
 
@@ -2387,14 +3314,14 @@ uint32_t SkewedInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->skewedColNames.clear();
-            uint32_t _size99;
-            ::apache::thrift::protocol::TType _etype102;
-            xfer += iprot->readListBegin(_etype102, _size99);
-            this->skewedColNames.resize(_size99);
-            uint32_t _i103;
-            for (_i103 = 0; _i103 < _size99; ++_i103)
+            uint32_t _size141;
+            ::apache::thrift::protocol::TType _etype144;
+            xfer += iprot->readListBegin(_etype144, _size141);
+            this->skewedColNames.resize(_size141);
+            uint32_t _i145;
+            for (_i145 = 0; _i145 < _size141; ++_i145)
             {
-              xfer += iprot->readString(this->skewedColNames[_i103]);
+              xfer += iprot->readString(this->skewedColNames[_i145]);
             }
             xfer += iprot->readListEnd();
           }
@@ -2407,23 +3334,23 @@ uint32_t SkewedInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->skewedColValues.clear();
-            uint32_t _size104;
-            ::apache::thrift::protocol::TType _etype107;
-            xfer += iprot->readListBegin(_etype107, _size104);
-            this->skewedColValues.resize(_size104);
-            uint32_t _i108;
-            for (_i108 = 0; _i108 < _size104; ++_i108)
+            uint32_t _size146;
+            ::apache::thrift::protocol::TType _etype149;
+            xfer += iprot->readListBegin(_etype149, _size146);
+            this->skewedColValues.resize(_size146);
+            uint32_t _i150;
+            for (_i150 = 0; _i150 < _size146; ++_i150)
             {
               {
-                this->skewedColValues[_i108].clear();
-                uint32_t _size109;
-                ::apache::thrift::protocol::TType _etype112;
-                xfer += iprot->readListBegin(_etype112, _size109);
-                this->skewedColValues[_i108].resize(_size109);
-                uint32_t _i113;
-                for (_i113 = 0; _i113 < _size109; ++_i113)
+                this->skewedColValues[_i150].clear();
+                uint32_t _size151;
+                ::apache::thrift::protocol::TType _etype154;
+                xfer += iprot->readListBegin(_etype154, _size151);
+                this->skewedColValues[_i150].resize(_size151);
+                uint32_t _i155;
+                for (_i155 = 0; _i155 < _size151; ++_i155)
                 {
-                  xfer += iprot->readString(this->skewedColValues[_i108][_i113]);
+                  xfer += iprot->readString(this->skewedColValues[_i150][_i155]);
                 }
                 xfer += iprot->readListEnd();
               }
@@ -2439,29 +3366,29 @@ uint32_t SkewedInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
         if (ftype == ::apache::thrift::protocol::T_MAP) {
           {
             this->skewedColValueLocationMaps.clear();
-            uint32_t _size114;
-            ::apache::thrift::protocol::TType _ktype115;
-            ::apache::thrift::protocol::TType _vtype116;
-            xfer += iprot->readMapBegin(_ktype115, _vtype116, _size114);
-            uint32_t _i118;
-            for (_i118 = 0; _i118 < _size114; ++_i118)
+            uint32_t _size156;
+            ::apache::thrift::protocol::TType _ktype157;
+            ::apache::thrift::protocol::TType _vtype158;
+            xfer += iprot->readMapBegin(_ktype157, _vtype158, _size156);
+            uint32_t _i160;
+            for (_i160 = 0; _i160 < _size156; ++_i160)
             {
-              std::vector<std::string>  _key119;
+              std::vector<std::string>  _key161;
               {
-                _key119.clear();
-                uint32_t _size121;
-                ::apache::thrift::protocol::TType _etype124;
-                xfer += iprot->readListBegin(_etype124, _size121);
-                _key119.resize(_size121);
-                uint32_t _i125;
-                for (_i125 = 0; _i125 < _size121; ++_i125)
+                _key161.clear();
+                uint32_t _size163;
+                ::apache::thrift::protocol::TType _etype166;
+                xfer += iprot->readListBegin(_etype166, _size163);
+                _key161.resize(_size163);
+                uint32_t _i167;
+                for (_i167 = 0; _i167 < _size163; ++_i167)
                 {
-                  xfer += iprot->readString(_key119[_i125]);
+                  xfer += iprot->readString(_key161[_i167]);
                 }
                 xfer += iprot->readListEnd();
               }
-              std::string& _val120 = this->skewedColValueLocationMaps[_key119];
-              xfer += iprot->readString(_val120);
+              std::string& _val162 = this->skewedColValueLocationMaps[_key161];
+              xfer += iprot->readString(_val162);
             }
             xfer += iprot->readMapEnd();
           }
@@ -2484,15 +3411,16 @@ uint32_t SkewedInfo::read(::apache::thrift::protocol::TProtocol* iprot) {
 
 uint32_t SkewedInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   uint32_t xfer = 0;
+  oprot->incrementRecursionDepth();
   xfer += oprot->writeStructBegin("SkewedInfo");
 
   xfer += oprot->writeFieldBegin("skewedColNames", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->skewedColNames.size()));
-    std::vector<std::string> ::const_iterator _iter126;
-    for (_iter126 = this->skewedColNames.begin(); _iter126 != this->skewedColNames.end(); ++_iter126)
+    std::vector<std::string> ::const_iterator _iter168;
+    for (_iter168 = this->skewedColNames.begin(); _iter168 != this->skewedColNames.end(); ++_iter168)
     {
-      xfer += oprot->writeString((*_iter126));
+      xfer += oprot->writeString((*_iter168));
     }
     xfer += oprot->writeListEnd();
   }
@@ -2501,15 +3429,15 @@ uint32_t SkewedInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("skewedColValues", ::apache::thrift::protocol::T_LIST, 2);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_LIST, static_cast<uint32_t>(this->skewedColValues.size()));
-    std::vector<std::vector<std::string> > ::const_iterator _iter127;
-    for (_iter127 = this->skewedColValues.begin(); _iter127 != this->skewedColValues.end(); ++_iter127)
+    std::vector<std::vector<std::string> > ::const_iterator _iter169;
+    for (_iter169 = this->skewedColValues.begin(); _iter169 != this->skewedColValues.end(); ++_iter169)
     {
       {
-        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*_iter127).size()));
-        std::vector<std::string> ::const_iterator _iter128;
-        for (_iter128 = (*_iter127).begin(); _iter128 != (*_iter127).end(); ++_iter128)
+        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>((*_iter169).size()));
+        std::vector<std::string> ::const_iterator _iter170;
+        for (_iter170 = (*_iter169).begin(); _iter170 != (*_iter169).end(); ++_iter170)
         {
-          xfer += oprot->writeString((*_iter128));
+          xfer += oprot->writeString((*_iter170));
         }
         xfer += oprot->writeListEnd();
       }
@@ -2521,19 +3449,19 @@ uint32_t SkewedInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
   xfer += oprot->writeFieldBegin("skewedColValueLocationMaps", ::apache::thrift::protocol::T_MAP, 3);
   {
     xfer += oprot->writeMapBegin(::apache::thrift::protocol::T_LIST, ::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(this->skewedColValueLocationMaps.size()));
-    std::map<std::vector<std::string> , std::string> ::const_iterator _iter129;
-    for (_iter129 = this->skewedColValueLocationMaps.begin(); _iter129 != this->skewedColValueLocationMaps.end(); ++_iter129)
+    std::map<std::vector<std::string> , std::string> ::const_iterator _iter171;
+    for (_iter171 = this->skewedColValueLocationMaps.begin(); _iter171 != this->skewedColValueLocationMaps.end(); ++_iter171)
     {
       {
-        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(_iter129->first.size()));
-        std::vector<std::string> ::const_iterator _iter130;
-        for (_iter130 = _iter129->first.begin(); _iter130 != _iter129->first.end(); ++_iter130)
+        xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRING, static_cast<uint32_t>(_iter171->first.size()));
+        std::vector<std::string> ::const_iterator _iter172;
+        for (_iter172 = _iter171->first.begin(); _iter172 != _iter171->first.end(); ++_iter172)
         {
-          xfer += oprot->writeString((*_iter130));
+          xfer += oprot->writeString((*_iter172));
         }
         xfer += oprot->writeListEnd();
       }
-      xfer += oprot->writeString(_iter129->second);
+      xfer += oprot->writeString(_iter171->second);
     }
     xfer += oprot->writeMapEnd();
   }
@@ -2541,6 +3469,7 @@ uint32_t SkewedInfo::write(::apache::thrift::protocol::TProtocol* oprot) const {
 
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
+  oprot->decrementRecursionDepth();
   return xfer;
 }
 
@@ -2552,6 +3481,84 @@ void swap(SkewedInfo &a, SkewedInfo &b) {
   swap(a.__isset, b.__isset);
 }
 
+SkewedInfo::SkewedInfo(const SkewedInfo& other173) {
+  skewedColNames = other173.skewedColNames;
+  skewedColValues = other173.skewedColValues;
+  skewedColValueLocationMaps = other173.skewedColValueLocationMaps;
+  __isset = other173.__isset;
+}
+SkewedInfo& SkewedInfo::operator=(const SkewedInfo& other174) {
+  skewedColNames = other174.skewedColNames;
+  skewedColValues = other174.skewedColValues;
+  skewedColValueLocationMaps = other174.skewedColValueLocationMaps;
+  __isset = other174.__isset;
+  return *this;
+}
+std::ostream& operator<<(std::ostream& out, const SkewedInfo& obj) {
+  using apache::thrift::to_string;
+  out << "SkewedInfo(";
+  out << "skewedColNames=" << to_string(obj.skewedColNames);
+  out << ", " << "skewedColValues=" << to_string(obj.skewedColValues);
+  out << ", " << "skewedColValueLocationMaps=" << to_string(obj.skewedColValueLocationMaps);
+  out << ")";
+  return out;
+}
+
+
+StorageDescriptor::~StorageDescriptor() throw() {
+}
+
+
+void StorageDescriptor::__set_cols(const std::vector<FieldSchema> & val) {
+  this->cols = val;
+}
+
+void StorageDescriptor::__set_location(const std::string& val) {
+  this->location = val;
+}
+
+void StorageDescriptor::__set_inputFormat(const std::string& val) {
+  this->inputFormat = val;
+}
+
+void StorageDescriptor::__set_outputFormat(const std::string& val) {
+  this->outputFormat = val;
+}
+
+void StorageDescriptor::__set_compressed(const bool val) {
+  this->compressed = val;
+}
+
+void StorageDescriptor::__set_numBuckets(const int32_t val) {
+  this->numBuckets = val;
+}
+
+void StorageDescriptor::__set_serdeInfo(const SerDeInfo& val) {
+  this

<TRUNCATED>

[23/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning.q
----------------------------------------------------------------------
diff --git a/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning.q b/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning.q
new file mode 100644
index 0000000..8b83ef6
--- /dev/null
+++ b/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning.q
@@ -0,0 +1,180 @@
+set hive.support.sql11.reserved.keywords=false;
+set hive.optimize.ppd=true;
+set hive.ppd.remove.duplicatefilters=true;
+set hive.spark.dynamic.partition.pruning=true;
+set hive.optimize.metadataonly=false;
+set hive.optimize.index.filter=true;
+
+-- SORT_QUERY_RESULTS
+
+select distinct ds from srcpart;
+select distinct hr from srcpart;
+
+EXPLAIN create table srcpart_date as select ds as ds, ds as date from srcpart group by ds;
+create table srcpart_date as select ds as ds, ds as date from srcpart group by ds;
+create table srcpart_hour as select hr as hr, hr as hour from srcpart group by hr;
+create table srcpart_date_hour as select ds as ds, ds as date, hr as hr, hr as hour from srcpart group by ds, hr;
+create table srcpart_double_hour as select (hr*2) as hr, hr as hour from srcpart group by hr;
+
+-- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where hr = 11 and ds = '2008-04-08';
+
+-- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = '2008-04-08' and hr = 11;
+
+-- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = 'I DONT EXIST';
+
+-- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where cast(hr as string) = 11;
+
+
+-- parent is reduce tasks
+EXPLAIN select count(*) from srcpart join (select ds as ds, ds as date from srcpart group by ds) s on (srcpart.ds = s.ds) where s.date = '2008-04-08';
+select count(*) from srcpart join (select ds as ds, ds as date from srcpart group by ds) s on (srcpart.ds = s.ds) where s.date = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- non-equi join
+EXPLAIN select count(*) from srcpart, srcpart_date_hour where (srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11) and (srcpart.ds = srcpart_date_hour.ds or srcpart.hr = srcpart_date_hour.hr);
+select count(*) from srcpart, srcpart_date_hour where (srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11) and (srcpart.ds = srcpart_date_hour.ds or srcpart.hr = srcpart_date_hour.hr);
+
+-- old style join syntax
+EXPLAIN select count(*) from srcpart, srcpart_date_hour where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11 and srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr;
+select count(*) from srcpart, srcpart_date_hour where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11 and srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr;
+
+-- left join
+EXPLAIN select count(*) from srcpart left join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+EXPLAIN select count(*) from srcpart_date left join srcpart on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+
+-- full outer
+EXPLAIN select count(*) from srcpart full outer join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+
+-- with static pruning
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart.hr = 13;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart.hr = 13;
+
+-- union + subquery
+EXPLAIN select count(*) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select count(*) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+EXPLAIN select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+EXPLAIN select ds from (select distinct(ds) as ds from srcpart union all select distinct(ds) as ds from srcpart) s where s.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select ds from (select distinct(ds) as ds from srcpart union all select distinct(ds) as ds from srcpart) s where s.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+
+set hive.auto.convert.join=true;
+set hive.auto.convert.join.noconditionaltask = true;
+set hive.auto.convert.join.noconditionaltask.size = 10000000;
+
+-- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart where hr = 11 and ds = '2008-04-08';
+
+-- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.date = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart where ds = '2008-04-08' and hr = 11;
+
+-- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+-- Disabled until TEZ-1486 is fixed
+-- select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = 'I DONT EXIST';
+
+-- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart where hr = 11;
+
+-- parent is reduce tasks
+EXPLAIN select count(*) from srcpart join (select ds as ds, ds as date from srcpart group by ds) s on (srcpart.ds = s.ds) where s.date = '2008-04-08';
+select count(*) from srcpart join (select ds as ds, ds as date from srcpart group by ds) s on (srcpart.ds = s.ds) where s.date = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- left join
+EXPLAIN select count(*) from srcpart left join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+EXPLAIN select count(*) from srcpart_date left join srcpart on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+
+-- full outer
+EXPLAIN select count(*) from srcpart full outer join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.date = '2008-04-08';
+
+-- with static pruning
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.date = '2008-04-08' and srcpart.hr = 13;
+-- Disabled until TEZ-1486 is fixed
+-- select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+-- where srcpart_date.date = '2008-04-08' and srcpart.hr = 13;
+
+-- union + subquery
+EXPLAIN select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+
+
+drop table srcpart_orc;
+drop table srcpart_date;
+drop table srcpart_hour;
+drop table srcpart_date_hour;
+drop table srcpart_double_hour;

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning_2.q
----------------------------------------------------------------------
diff --git a/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning_2.q b/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning_2.q
new file mode 100644
index 0000000..734f187
--- /dev/null
+++ b/ql/src/test/queries/clientpositive/spark_dynamic_partition_pruning_2.q
@@ -0,0 +1,118 @@
+set hive.optimize.ppd=true;
+set hive.ppd.remove.duplicatefilters=true;
+set hive.spark.dynamic.partition.pruning=true;
+set hive.optimize.metadataonly=false;
+set hive.optimize.index.filter=true;
+set hive.auto.convert.join=true;
+set hive.auto.convert.join.noconditionaltask = true;
+set hive.auto.convert.join.noconditionaltask.size = 10000000;
+
+-- SORT_QUERY_RESULTS
+
+create table dim_shops (id int, label string) row format delimited fields terminated by ',' stored as textfile;
+load data local inpath '../../data/files/dim_shops.txt' into table dim_shops;
+
+create table agg_01 (amount decimal) partitioned by (dim_shops_id int) row format delimited fields terminated by ',' stored as textfile;
+alter table agg_01 add partition (dim_shops_id = 1);
+alter table agg_01 add partition (dim_shops_id = 2);
+alter table agg_01 add partition (dim_shops_id = 3);
+
+load data local inpath '../../data/files/agg_01-p1.txt' into table agg_01 partition (dim_shops_id=1);
+load data local inpath '../../data/files/agg_01-p2.txt' into table agg_01 partition (dim_shops_id=2);
+load data local inpath '../../data/files/agg_01-p3.txt' into table agg_01 partition (dim_shops_id=3);
+
+analyze table dim_shops compute statistics;
+analyze table agg_01 partition (dim_shops_id) compute statistics;
+
+select * from dim_shops;
+select * from agg_01;
+
+EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+set hive.spark.dynamic.partition.pruning.max.data.size=1;
+
+EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+EXPLAIN SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id;
+
+SELECT d1.label
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id;
+
+EXPLAIN SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1;
+
+SELECT agg.amount
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and agg.dim_shops_id = 1;
+
+set hive.spark.dynamic.partition.pruning.max.data.size=1000000;
+
+EXPLAIN SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+SELECT d1.label, count(*), sum(agg.amount)
+FROM agg_01 agg,
+dim_shops d1
+WHERE agg.dim_shops_id = d1.id
+and
+d1.label in ('foo', 'bar')
+GROUP BY d1.label
+ORDER BY d1.label;
+
+
+EXPLAIN 
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar';
+
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'foo'
+UNION ALL
+SELECT amount FROM agg_01, dim_shops WHERE dim_shops_id = id AND label = 'bar';

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/queries/clientpositive/spark_vectorized_dynamic_partition_pruning.q
----------------------------------------------------------------------
diff --git a/ql/src/test/queries/clientpositive/spark_vectorized_dynamic_partition_pruning.q b/ql/src/test/queries/clientpositive/spark_vectorized_dynamic_partition_pruning.q
new file mode 100644
index 0000000..293fcfc
--- /dev/null
+++ b/ql/src/test/queries/clientpositive/spark_vectorized_dynamic_partition_pruning.q
@@ -0,0 +1,192 @@
+set hive.optimize.ppd=true;
+set hive.ppd.remove.duplicatefilters=true;
+set hive.spark.dynamic.partition.pruning=true;
+set hive.optimize.metadataonly=false;
+set hive.optimize.index.filter=true;
+set hive.vectorized.execution.enabled=true;
+
+
+select distinct ds from srcpart;
+select distinct hr from srcpart;
+
+EXPLAIN create table srcpart_date as select ds as ds, ds as `date` from srcpart group by ds;
+create table srcpart_date stored as orc as select ds as ds, ds as `date` from srcpart group by ds;
+create table srcpart_hour stored as orc as select hr as hr, hr as hour from srcpart group by hr;
+create table srcpart_date_hour stored as orc as select ds as ds, ds as `date`, hr as hr, hr as hour from srcpart group by ds, hr;
+create table srcpart_double_hour stored as orc as select (hr*2) as hr, hr as hour from srcpart group by hr;
+
+-- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where hr = 11 and ds = '2008-04-08';
+
+-- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = '2008-04-08' and hr = 11;
+
+-- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where ds = 'I DONT EXIST';
+
+-- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=false;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (cast(srcpart.hr*2 as string) = cast(srcpart_double_hour.hr as string)) where srcpart_double_hour.hour = 11;
+set hive.spark.dynamic.partition.pruning=true;
+select count(*) from srcpart where cast(hr as string) = 11;
+
+
+-- parent is reduce tasks
+EXPLAIN select count(*) from srcpart join (select ds as ds, ds as `date` from srcpart group by ds) s on (srcpart.ds = s.ds) where s.`date` = '2008-04-08';
+select count(*) from srcpart join (select ds as ds, ds as `date` from srcpart group by ds) s on (srcpart.ds = s.ds) where s.`date` = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- non-equi join
+EXPLAIN select count(*) from srcpart, srcpart_date_hour where (srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11) and (srcpart.ds = srcpart_date_hour.ds or srcpart.hr = srcpart_date_hour.hr);
+select count(*) from srcpart, srcpart_date_hour where (srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11) and (srcpart.ds = srcpart_date_hour.ds or srcpart.hr = srcpart_date_hour.hr);
+
+-- old style join syntax
+EXPLAIN select count(*) from srcpart, srcpart_date_hour where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11 and srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr;
+select count(*) from srcpart, srcpart_date_hour where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11 and srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr;
+
+-- left join
+EXPLAIN select count(*) from srcpart left join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+EXPLAIN select count(*) from srcpart_date left join srcpart on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+
+-- full outer
+EXPLAIN select count(*) from srcpart full outer join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+
+-- with static pruning
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart.hr = 13;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart.hr = 13;
+
+-- union + subquery
+EXPLAIN select count(*) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select count(*) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+EXPLAIN select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+EXPLAIN select ds from (select distinct(ds) as ds from srcpart union all select distinct(ds) as ds from srcpart) s where s.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select ds from (select distinct(ds) as ds from srcpart union all select distinct(ds) as ds from srcpart) s where s.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+
+set hive.auto.convert.join=true;
+set hive.auto.convert.join.noconditionaltask = true;
+set hive.auto.convert.join.noconditionaltask.size = 10000000;
+
+-- single column, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- multiple sources, single key
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11;
+select count(*) from srcpart where hr = 11 and ds = '2008-04-08';
+
+-- multiple columns single source
+EXPLAIN select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart join srcpart_date_hour on (srcpart.ds = srcpart_date_hour.ds and srcpart.hr = srcpart_date_hour.hr) where srcpart_date_hour.`date` = '2008-04-08' and srcpart_date_hour.hour = 11;
+select count(*) from srcpart where ds = '2008-04-08' and hr = 11;
+
+-- empty set
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+-- Disabled until TEZ-1486 is fixed
+-- select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = 'I DONT EXIST';
+
+-- expressions
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr = cast(srcpart_double_hour.hr/2 as int)) where srcpart_double_hour.hour = 11;
+EXPLAIN select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart join srcpart_double_hour on (srcpart.hr*2 = srcpart_double_hour.hr) where srcpart_double_hour.hour = 11;
+select count(*) from srcpart where hr = 11;
+
+-- parent is reduce tasks
+EXPLAIN select count(*) from srcpart join (select ds as ds, ds as `date` from srcpart group by ds) s on (srcpart.ds = s.ds) where s.`date` = '2008-04-08';
+select count(*) from srcpart join (select ds as ds, ds as `date` from srcpart group by ds) s on (srcpart.ds = s.ds) where s.`date` = '2008-04-08';
+select count(*) from srcpart where ds = '2008-04-08';
+
+-- left join
+EXPLAIN select count(*) from srcpart left join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+EXPLAIN select count(*) from srcpart_date left join srcpart on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+
+-- full outer
+EXPLAIN select count(*) from srcpart full outer join srcpart_date on (srcpart.ds = srcpart_date.ds) where srcpart_date.`date` = '2008-04-08';
+
+-- with static pruning
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart_hour.hour = 11 and srcpart.hr = 11;
+EXPLAIN select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+where srcpart_date.`date` = '2008-04-08' and srcpart.hr = 13;
+-- Disabled until TEZ-1486 is fixed
+-- select count(*) from srcpart join srcpart_date on (srcpart.ds = srcpart_date.ds) join srcpart_hour on (srcpart.hr = srcpart_hour.hr) 
+-- where srcpart_date.`date` = '2008-04-08' and srcpart.hr = 13;
+
+-- union + subquery
+EXPLAIN select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+select distinct(ds) from srcpart where srcpart.ds in (select max(srcpart.ds) from srcpart union all select min(srcpart.ds) from srcpart);
+
+
+-- different file format
+create table srcpart_orc (key int, value string) partitioned by (ds string, hr int) stored as orc;
+
+
+set hive.exec.dynamic.partition.mode=nonstrict;
+set hive.vectorized.execution.enabled=false;
+set hive.exec.max.dynamic.partitions=1000;
+
+insert into table srcpart_orc partition (ds, hr) select key, value, ds, hr from srcpart;
+EXPLAIN select count(*) from srcpart_orc join srcpart_date_hour on (srcpart_orc.ds = srcpart_date_hour.ds and srcpart_orc.hr = srcpart_date_hour.hr) where srcpart_date_hour.hour = 11 and (srcpart_date_hour.`date` = '2008-04-08' or srcpart_date_hour.`date` = '2008-04-09');
+select count(*) from srcpart_orc join srcpart_date_hour on (srcpart_orc.ds = srcpart_date_hour.ds and srcpart_orc.hr = srcpart_date_hour.hr) where srcpart_date_hour.hour = 11 and (srcpart_date_hour.`date` = '2008-04-08' or srcpart_date_hour.`date` = '2008-04-09');
+select count(*) from srcpart where (ds = '2008-04-08' or ds = '2008-04-09') and hr = 11;
+
+drop table srcpart_orc;
+drop table srcpart_date;
+drop table srcpart_hour;
+drop table srcpart_date_hour;
+drop table srcpart_double_hour;

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/bucket2.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/bucket2.q.out b/ql/src/test/results/clientpositive/spark/bucket2.q.out
index 89c3b4c..8bb53d5 100644
--- a/ql/src/test/results/clientpositive/spark/bucket2.q.out
+++ b/ql/src/test/results/clientpositive/spark/bucket2.q.out
@@ -203,14 +203,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: s
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (((hash(key) & 2147483647) % 2) = 0) (type: boolean)
-            Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string)
               outputColumnNames: _col0, _col1
-              Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select * from bucket2_1 tablesample (bucket 1 out of 2) s

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/bucket3.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/bucket3.q.out b/ql/src/test/results/clientpositive/spark/bucket3.q.out
index 2fc4855..b25ea05 100644
--- a/ql/src/test/results/clientpositive/spark/bucket3.q.out
+++ b/ql/src/test/results/clientpositive/spark/bucket3.q.out
@@ -226,14 +226,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: s
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (((hash(key) & 2147483647) % 2) = 0) (type: boolean)
-            Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string), '1' (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select * from bucket3_1 tablesample (bucket 1 out of 2) s where ds = '1'

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/bucket4.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/bucket4.q.out b/ql/src/test/results/clientpositive/spark/bucket4.q.out
index 44e0f9f..2ad59da 100644
--- a/ql/src/test/results/clientpositive/spark/bucket4.q.out
+++ b/ql/src/test/results/clientpositive/spark/bucket4.q.out
@@ -202,14 +202,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: s
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (((hash(key) & 2147483647) % 2) = 0) (type: boolean)
-            Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string)
               outputColumnNames: _col0, _col1
-              Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select * from bucket4_1 tablesample (bucket 1 out of 2) s

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/column_access_stats.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/column_access_stats.q.out b/ql/src/test/results/clientpositive/spark/column_access_stats.q.out
index 7879ef1..5803093 100644
--- a/ql/src/test/results/clientpositive/spark/column_access_stats.q.out
+++ b/ql/src/test/results/clientpositive/spark/column_access_stats.q.out
@@ -92,11 +92,9 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: t1
-          Statistics: Num rows: 1 Data size: 30 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: key (type: string)
             outputColumnNames: _col0
-            Statistics: Num rows: 1 Data size: 30 Basic stats: COMPLETE Column stats: NONE
             ListSink
 
 PREHOOK: query: SELECT key FROM (SELECT key, val FROM T1) subq1
@@ -124,11 +122,9 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: t1
-          Statistics: Num rows: 1 Data size: 30 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: key (type: string)
             outputColumnNames: _col0
-            Statistics: Num rows: 1 Data size: 30 Basic stats: COMPLETE Column stats: NONE
             ListSink
 
 PREHOOK: query: SELECT k FROM (SELECT key as k, val as v FROM T1) subq1

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/limit_partition_metadataonly.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/limit_partition_metadataonly.q.out b/ql/src/test/results/clientpositive/spark/limit_partition_metadataonly.q.out
index c6f9039..a34a399 100644
--- a/ql/src/test/results/clientpositive/spark/limit_partition_metadataonly.q.out
+++ b/ql/src/test/results/clientpositive/spark/limit_partition_metadataonly.q.out
@@ -16,11 +16,9 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: srcpart
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: '2008-04-08' (type: string)
             outputColumnNames: _col0
-            Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
             ListSink
 
 PREHOOK: query: select ds from srcpart where hr=11 and ds='2008-04-08'

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/list_bucket_dml_2.q.java1.7.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/list_bucket_dml_2.q.java1.7.out b/ql/src/test/results/clientpositive/spark/list_bucket_dml_2.q.java1.7.out
index e38ccf8..603e6bb 100644
--- a/ql/src/test/results/clientpositive/spark/list_bucket_dml_2.q.java1.7.out
+++ b/ql/src/test/results/clientpositive/spark/list_bucket_dml_2.q.java1.7.out
@@ -461,16 +461,13 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: list_bucketing_static_part
-          Statistics: Num rows: 1000 Data size: 9624 Basic stats: COMPLETE Column stats: NONE
           GatherStats: false
           Filter Operator
             isSamplingPred: false
             predicate: ((key = '484') and (value = 'val_484')) (type: boolean)
-            Statistics: Num rows: 250 Data size: 2406 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: '484' (type: string), 'val_484' (type: string), '2008-04-08' (type: string), '11' (type: string)
               outputColumnNames: _col0, _col1, _col2, _col3
-              Statistics: Num rows: 250 Data size: 2406 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select * from list_bucketing_static_part where ds = '2008-04-08' and  hr = '11' and key = '484' and value = 'val_484'

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/optimize_nullscan.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/optimize_nullscan.q.out b/ql/src/test/results/clientpositive/spark/optimize_nullscan.q.out
index a324abc..506d265 100644
--- a/ql/src/test/results/clientpositive/spark/optimize_nullscan.q.out
+++ b/ql/src/test/results/clientpositive/spark/optimize_nullscan.q.out
@@ -43,16 +43,13 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: src
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           GatherStats: false
           Filter Operator
             isSamplingPred: false
             predicate: false (type: boolean)
-            Statistics: Num rows: 1 Data size: 10 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: string)
               outputColumnNames: _col0
-              Statistics: Num rows: 1 Data size: 10 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: select key from src where false

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/pcr.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/pcr.q.out b/ql/src/test/results/clientpositive/spark/pcr.q.out
index efadb1d..fb08f10 100644
--- a/ql/src/test/results/clientpositive/spark/pcr.q.out
+++ b/ql/src/test/results/clientpositive/spark/pcr.q.out
@@ -5461,11 +5461,9 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: srcpart
-          Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: key (type: string), value (type: string)
             outputColumnNames: _col0, _col1
-            Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
             ListSink
 
 PREHOOK: query: explain select key,value from srcpart where hr  = cast(11 as double)
@@ -5482,11 +5480,9 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: srcpart
-          Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: key (type: string), value (type: string)
             outputColumnNames: _col0, _col1
-            Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
             ListSink
 
 PREHOOK: query: explain select key,value from srcpart where cast(hr as double)  = 11
@@ -5503,10 +5499,8 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: srcpart
-          Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: key (type: string), value (type: string)
             outputColumnNames: _col0, _col1
-            Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
             ListSink
 

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/sample3.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/sample3.q.out b/ql/src/test/results/clientpositive/spark/sample3.q.out
index 2fe6b0d..35a4352 100644
--- a/ql/src/test/results/clientpositive/spark/sample3.q.out
+++ b/ql/src/test/results/clientpositive/spark/sample3.q.out
@@ -22,14 +22,11 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: s
-          Statistics: Num rows: 1000 Data size: 10603 Basic stats: COMPLETE Column stats: NONE
           Filter Operator
             predicate: (((hash(key) & 2147483647) % 5) = 0) (type: boolean)
-            Statistics: Num rows: 500 Data size: 5301 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int)
               outputColumnNames: _col0
-              Statistics: Num rows: 500 Data size: 5301 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: SELECT s.key

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/sample9.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/sample9.q.out b/ql/src/test/results/clientpositive/spark/sample9.q.out
index c9823f7..1a84bd6 100644
--- a/ql/src/test/results/clientpositive/spark/sample9.q.out
+++ b/ql/src/test/results/clientpositive/spark/sample9.q.out
@@ -53,17 +53,14 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: a
-          Statistics: Num rows: 1000 Data size: 10603 Basic stats: COMPLETE Column stats: NONE
           GatherStats: false
           Filter Operator
             isSamplingPred: true
             predicate: (((hash(key) & 2147483647) % 2) = 0) (type: boolean)
             sampleDesc: BUCKET 1 OUT OF 2
-            Statistics: Num rows: 500 Data size: 5301 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string)
               outputColumnNames: _col0, _col1
-              Statistics: Num rows: 500 Data size: 5301 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: SELECT s.*

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/ql/src/test/results/clientpositive/spark/smb_mapjoin_11.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/spark/smb_mapjoin_11.q.out b/ql/src/test/results/clientpositive/spark/smb_mapjoin_11.q.out
index c94cc5b..4d912ca 100644
--- a/ql/src/test/results/clientpositive/spark/smb_mapjoin_11.q.out
+++ b/ql/src/test/results/clientpositive/spark/smb_mapjoin_11.q.out
@@ -1912,17 +1912,14 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: test_table1
-          Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
           GatherStats: false
           Filter Operator
             isSamplingPred: true
             predicate: (((hash(key) & 2147483647) % 16) = 1) (type: boolean)
             sampleDesc: BUCKET 2 OUT OF 16
-            Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string), ds (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: EXPLAIN EXTENDED SELECT * FROM test_table3 TABLESAMPLE(BUCKET 2 OUT OF 16)
@@ -2004,17 +2001,14 @@ STAGE PLANS:
       Processor Tree:
         TableScan
           alias: test_table3
-          Statistics: Num rows: 1028 Data size: 10968 Basic stats: COMPLETE Column stats: NONE
           GatherStats: false
           Filter Operator
             isSamplingPred: true
             predicate: (((hash(key) & 2147483647) % 16) = 1) (type: boolean)
             sampleDesc: BUCKET 2 OUT OF 16
-            Statistics: Num rows: 514 Data size: 5484 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: key (type: int), value (type: string), ds (type: string)
               outputColumnNames: _col0, _col1, _col2
-              Statistics: Num rows: 514 Data size: 5484 Basic stats: COMPLETE Column stats: NONE
               ListSink
 
 PREHOOK: query: SELECT * FROM test_table1 TABLESAMPLE(BUCKET 2 OUT OF 16)


[32/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnAbortedException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnAbortedException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnAbortedException.java
index ae39507..101c053 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnAbortedException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnAbortedException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TxnAbortedException extends TException implements org.apache.thrift.TBase<TxnAbortedException, TxnAbortedException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TxnAbortedException extends TException implements org.apache.thrift.TBase<TxnAbortedException, TxnAbortedException._Fields>, java.io.Serializable, Cloneable, Comparable<TxnAbortedException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TxnAbortedException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class TxnAbortedException extends TException implements org.apache.thrift
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TxnAbortedException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TxnAbortedException typedOther = (TxnAbortedException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnInfo.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnInfo.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnInfo.java
index 18cbe53..53ea62d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnInfo.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnInfo.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TxnInfo implements org.apache.thrift.TBase<TxnInfo, TxnInfo._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TxnInfo implements org.apache.thrift.TBase<TxnInfo, TxnInfo._Fields>, java.io.Serializable, Cloneable, Comparable<TxnInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TxnInfo");
 
   private static final org.apache.thrift.protocol.TField ID_FIELD_DESC = new org.apache.thrift.protocol.TField("id", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -413,75 +417,75 @@ public class TxnInfo implements org.apache.thrift.TBase<TxnInfo, TxnInfo._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_id = true;
-    builder.append(present_id);
+    list.add(present_id);
     if (present_id)
-      builder.append(id);
+      list.add(id);
 
     boolean present_state = true && (isSetState());
-    builder.append(present_state);
+    list.add(present_state);
     if (present_state)
-      builder.append(state.getValue());
+      list.add(state.getValue());
 
     boolean present_user = true && (isSetUser());
-    builder.append(present_user);
+    list.add(present_user);
     if (present_user)
-      builder.append(user);
+      list.add(user);
 
     boolean present_hostname = true && (isSetHostname());
-    builder.append(present_hostname);
+    list.add(present_hostname);
     if (present_hostname)
-      builder.append(hostname);
+      list.add(hostname);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TxnInfo other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TxnInfo typedOther = (TxnInfo)other;
 
-    lastComparison = Boolean.valueOf(isSetId()).compareTo(typedOther.isSetId());
+    lastComparison = Boolean.valueOf(isSetId()).compareTo(other.isSetId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.id, typedOther.id);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.id, other.id);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetState()).compareTo(typedOther.isSetState());
+    lastComparison = Boolean.valueOf(isSetState()).compareTo(other.isSetState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, typedOther.state);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.state, other.state);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUser()).compareTo(typedOther.isSetUser());
+    lastComparison = Boolean.valueOf(isSetUser()).compareTo(other.isSetUser());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUser()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, typedOther.user);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.user, other.user);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(typedOther.isSetHostname());
+    lastComparison = Boolean.valueOf(isSetHostname()).compareTo(other.isSetHostname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHostname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, typedOther.hostname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hostname, other.hostname);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -604,7 +608,7 @@ public class TxnInfo implements org.apache.thrift.TBase<TxnInfo, TxnInfo._Fields
             break;
           case 2: // STATE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.state = TxnState.findByValue(iprot.readI32());
+              struct.state = org.apache.hadoop.hive.metastore.api.TxnState.findByValue(iprot.readI32());
               struct.setStateIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -685,7 +689,7 @@ public class TxnInfo implements org.apache.thrift.TBase<TxnInfo, TxnInfo._Fields
       TTupleProtocol iprot = (TTupleProtocol) prot;
       struct.id = iprot.readI64();
       struct.setIdIsSet(true);
-      struct.state = TxnState.findByValue(iprot.readI32());
+      struct.state = org.apache.hadoop.hive.metastore.api.TxnState.findByValue(iprot.readI32());
       struct.setStateIsSet(true);
       struct.user = iprot.readString();
       struct.setUserIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnOpenException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnOpenException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnOpenException.java
index 4f5d02d..82e733c 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnOpenException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnOpenException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TxnOpenException extends TException implements org.apache.thrift.TBase<TxnOpenException, TxnOpenException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TxnOpenException extends TException implements org.apache.thrift.TBase<TxnOpenException, TxnOpenException._Fields>, java.io.Serializable, Cloneable, Comparable<TxnOpenException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TxnOpenException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class TxnOpenException extends TException implements org.apache.thrift.TB
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TxnOpenException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TxnOpenException typedOther = (TxnOpenException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnState.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnState.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnState.java
index f4540a1..69d6239 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnState.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/TxnState.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Type.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Type.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Type.java
index 1882b57..627a399 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Type.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Type.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.io.Serializable, Cloneable, Comparable<Type> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Type");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -118,7 +122,7 @@ public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.i
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.TYPE1,_Fields.TYPE2,_Fields.FIELDS};
+  private static final _Fields optionals[] = {_Fields.TYPE1,_Fields.TYPE2,_Fields.FIELDS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -159,7 +163,7 @@ public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.i
       this.type2 = other.type2;
     }
     if (other.isSetFields()) {
-      List<FieldSchema> __this__fields = new ArrayList<FieldSchema>();
+      List<FieldSchema> __this__fields = new ArrayList<FieldSchema>(other.fields.size());
       for (FieldSchema other_element : other.fields) {
         __this__fields.add(new FieldSchema(other_element));
       }
@@ -414,75 +418,75 @@ public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.i
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_name = true && (isSetName());
-    builder.append(present_name);
+    list.add(present_name);
     if (present_name)
-      builder.append(name);
+      list.add(name);
 
     boolean present_type1 = true && (isSetType1());
-    builder.append(present_type1);
+    list.add(present_type1);
     if (present_type1)
-      builder.append(type1);
+      list.add(type1);
 
     boolean present_type2 = true && (isSetType2());
-    builder.append(present_type2);
+    list.add(present_type2);
     if (present_type2)
-      builder.append(type2);
+      list.add(type2);
 
     boolean present_fields = true && (isSetFields());
-    builder.append(present_fields);
+    list.add(present_fields);
     if (present_fields)
-      builder.append(fields);
+      list.add(fields);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Type other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Type typedOther = (Type)other;
 
-    lastComparison = Boolean.valueOf(isSetName()).compareTo(typedOther.isSetName());
+    lastComparison = Boolean.valueOf(isSetName()).compareTo(other.isSetName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, typedOther.name);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, other.name);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType1()).compareTo(typedOther.isSetType1());
+    lastComparison = Boolean.valueOf(isSetType1()).compareTo(other.isSetType1());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType1()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type1, typedOther.type1);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type1, other.type1);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType2()).compareTo(typedOther.isSetType2());
+    lastComparison = Boolean.valueOf(isSetType2()).compareTo(other.isSetType2());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType2()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type2, typedOther.type2);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type2, other.type2);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetFields()).compareTo(typedOther.isSetFields());
+    lastComparison = Boolean.valueOf(isSetFields()).compareTo(other.isSetFields());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetFields()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fields, typedOther.fields);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.fields, other.fields);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -616,12 +620,12 @@ public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.i
               {
                 org.apache.thrift.protocol.TList _list0 = iprot.readListBegin();
                 struct.fields = new ArrayList<FieldSchema>(_list0.size);
-                for (int _i1 = 0; _i1 < _list0.size; ++_i1)
+                FieldSchema _elem1;
+                for (int _i2 = 0; _i2 < _list0.size; ++_i2)
                 {
-                  FieldSchema _elem2; // optional
-                  _elem2 = new FieldSchema();
-                  _elem2.read(iprot);
-                  struct.fields.add(_elem2);
+                  _elem1 = new FieldSchema();
+                  _elem1.read(iprot);
+                  struct.fields.add(_elem1);
                 }
                 iprot.readListEnd();
               }
@@ -747,12 +751,12 @@ public class Type implements org.apache.thrift.TBase<Type, Type._Fields>, java.i
         {
           org.apache.thrift.protocol.TList _list5 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.fields = new ArrayList<FieldSchema>(_list5.size);
-          for (int _i6 = 0; _i6 < _list5.size; ++_i6)
+          FieldSchema _elem6;
+          for (int _i7 = 0; _i7 < _list5.size; ++_i7)
           {
-            FieldSchema _elem7; // optional
-            _elem7 = new FieldSchema();
-            _elem7.read(iprot);
-            struct.fields.add(_elem7);
+            _elem6 = new FieldSchema();
+            _elem6.read(iprot);
+            struct.fields.add(_elem6);
           }
         }
         struct.setFieldsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownDBException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownDBException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownDBException.java
index ab91419..915f30d 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownDBException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownDBException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class UnknownDBException extends TException implements org.apache.thrift.TBase<UnknownDBException, UnknownDBException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class UnknownDBException extends TException implements org.apache.thrift.TBase<UnknownDBException, UnknownDBException._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownDBException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownDBException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class UnknownDBException extends TException implements org.apache.thrift.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(UnknownDBException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    UnknownDBException typedOther = (UnknownDBException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownPartitionException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownPartitionException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownPartitionException.java
index 7e28591..73e9280 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownPartitionException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownPartitionException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class UnknownPartitionException extends TException implements org.apache.thrift.TBase<UnknownPartitionException, UnknownPartitionException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class UnknownPartitionException extends TException implements org.apache.thrift.TBase<UnknownPartitionException, UnknownPartitionException._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownPartitionException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownPartitionException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class UnknownPartitionException extends TException implements org.apache.
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(UnknownPartitionException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    UnknownPartitionException typedOther = (UnknownPartitionException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownTableException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownTableException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownTableException.java
index 7aa8012..ba4c808 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownTableException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnknownTableException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class UnknownTableException extends TException implements org.apache.thrift.TBase<UnknownTableException, UnknownTableException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class UnknownTableException extends TException implements org.apache.thrift.TBase<UnknownTableException, UnknownTableException._Fields>, java.io.Serializable, Cloneable, Comparable<UnknownTableException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnknownTableException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class UnknownTableException extends TException implements org.apache.thri
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(UnknownTableException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    UnknownTableException typedOther = (UnknownTableException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnlockRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnlockRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnlockRequest.java
index 54b949d..7b09b58 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnlockRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/UnlockRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class UnlockRequest implements org.apache.thrift.TBase<UnlockRequest, UnlockRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class UnlockRequest implements org.apache.thrift.TBase<UnlockRequest, UnlockRequest._Fields>, java.io.Serializable, Cloneable, Comparable<UnlockRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("UnlockRequest");
 
   private static final org.apache.thrift.protocol.TField LOCKID_FIELD_DESC = new org.apache.thrift.protocol.TField("lockid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class UnlockRequest implements org.apache.thrift.TBase<UnlockRequest, Unl
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lockid = true;
-    builder.append(present_lockid);
+    list.add(present_lockid);
     if (present_lockid)
-      builder.append(lockid);
+      list.add(lockid);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(UnlockRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    UnlockRequest typedOther = (UnlockRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(typedOther.isSetLockid());
+    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(other.isSetLockid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLockid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, typedOther.lockid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, other.lockid);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Version.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Version.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Version.java
index aa83fd7..8833ad2 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Version.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Version.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Version implements org.apache.thrift.TBase<Version, Version._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Version implements org.apache.thrift.TBase<Version, Version._Fields>, java.io.Serializable, Cloneable, Comparable<Version> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Version");
 
   private static final org.apache.thrift.protocol.TField VERSION_FIELD_DESC = new org.apache.thrift.protocol.TField("version", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -283,45 +287,45 @@ public class Version implements org.apache.thrift.TBase<Version, Version._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_version = true && (isSetVersion());
-    builder.append(present_version);
+    list.add(present_version);
     if (present_version)
-      builder.append(version);
+      list.add(version);
 
     boolean present_comments = true && (isSetComments());
-    builder.append(present_comments);
+    list.add(present_comments);
     if (present_comments)
-      builder.append(comments);
+      list.add(comments);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Version other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Version typedOther = (Version)other;
 
-    lastComparison = Boolean.valueOf(isSetVersion()).compareTo(typedOther.isSetVersion());
+    lastComparison = Boolean.valueOf(isSetVersion()).compareTo(other.isSetVersion());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetVersion()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.version, typedOther.version);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.version, other.version);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetComments()).compareTo(typedOther.isSetComments());
+    lastComparison = Boolean.valueOf(isSetComments()).compareTo(other.isSetComments());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetComments()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comments, typedOther.comments);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.comments, other.comments);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/hive_metastoreConstants.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/hive_metastoreConstants.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/hive_metastoreConstants.java
index 0f2fca8..b6e0a29 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/hive_metastoreConstants.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/hive_metastoreConstants.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class hive_metastoreConstants {
 
   public static final String DDL_TIME = "transient_lastDdlTime";


[39/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeRequest.java
index 29ce977..70b839f 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<GrantRevokePrivilegeRequest, GrantRevokePrivilegeRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<GrantRevokePrivilegeRequest, GrantRevokePrivilegeRequest._Fields>, java.io.Serializable, Cloneable, Comparable<GrantRevokePrivilegeRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GrantRevokePrivilegeRequest");
 
   private static final org.apache.thrift.protocol.TField REQUEST_TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("requestType", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -119,7 +123,7 @@ public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<Gran
   // isset id assignments
   private static final int __REVOKEGRANTOPTION_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.REVOKE_GRANT_OPTION};
+  private static final _Fields optionals[] = {_Fields.REVOKE_GRANT_OPTION};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -353,60 +357,60 @@ public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<Gran
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_requestType = true && (isSetRequestType());
-    builder.append(present_requestType);
+    list.add(present_requestType);
     if (present_requestType)
-      builder.append(requestType.getValue());
+      list.add(requestType.getValue());
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
     boolean present_revokeGrantOption = true && (isSetRevokeGrantOption());
-    builder.append(present_revokeGrantOption);
+    list.add(present_revokeGrantOption);
     if (present_revokeGrantOption)
-      builder.append(revokeGrantOption);
+      list.add(revokeGrantOption);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GrantRevokePrivilegeRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GrantRevokePrivilegeRequest typedOther = (GrantRevokePrivilegeRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetRequestType()).compareTo(typedOther.isSetRequestType());
+    lastComparison = Boolean.valueOf(isSetRequestType()).compareTo(other.isSetRequestType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRequestType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.requestType, typedOther.requestType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.requestType, other.requestType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRevokeGrantOption()).compareTo(typedOther.isSetRevokeGrantOption());
+    lastComparison = Boolean.valueOf(isSetRevokeGrantOption()).compareTo(other.isSetRevokeGrantOption());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRevokeGrantOption()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.revokeGrantOption, typedOther.revokeGrantOption);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.revokeGrantOption, other.revokeGrantOption);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -502,7 +506,7 @@ public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<Gran
         switch (schemeField.id) {
           case 1: // REQUEST_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.requestType = GrantRevokeType.findByValue(iprot.readI32());
+              struct.requestType = org.apache.hadoop.hive.metastore.api.GrantRevokeType.findByValue(iprot.readI32());
               struct.setRequestTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -597,7 +601,7 @@ public class GrantRevokePrivilegeRequest implements org.apache.thrift.TBase<Gran
       TTupleProtocol iprot = (TTupleProtocol) prot;
       BitSet incoming = iprot.readBitSet(3);
       if (incoming.get(0)) {
-        struct.requestType = GrantRevokeType.findByValue(iprot.readI32());
+        struct.requestType = org.apache.hadoop.hive.metastore.api.GrantRevokeType.findByValue(iprot.readI32());
         struct.setRequestTypeIsSet(true);
       }
       if (incoming.get(1)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeResponse.java
index f86bf9f..169f35c 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokePrivilegeResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GrantRevokePrivilegeResponse implements org.apache.thrift.TBase<GrantRevokePrivilegeResponse, GrantRevokePrivilegeResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GrantRevokePrivilegeResponse implements org.apache.thrift.TBase<GrantRevokePrivilegeResponse, GrantRevokePrivilegeResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GrantRevokePrivilegeResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GrantRevokePrivilegeResponse");
 
   private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -105,7 +109,7 @@ public class GrantRevokePrivilegeResponse implements org.apache.thrift.TBase<Gra
   // isset id assignments
   private static final int __SUCCESS_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.SUCCESS};
+  private static final _Fields optionals[] = {_Fields.SUCCESS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class GrantRevokePrivilegeResponse implements org.apache.thrift.TBase<Gra
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_success = true && (isSetSuccess());
-    builder.append(present_success);
+    list.add(present_success);
     if (present_success)
-      builder.append(success);
+      list.add(success);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GrantRevokePrivilegeResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GrantRevokePrivilegeResponse typedOther = (GrantRevokePrivilegeResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+    lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSuccess()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleRequest.java
index db17aef..74384c9 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevokeRoleRequest, GrantRevokeRoleRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevokeRoleRequest, GrantRevokeRoleRequest._Fields>, java.io.Serializable, Cloneable, Comparable<GrantRevokeRoleRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GrantRevokeRoleRequest");
 
   private static final org.apache.thrift.protocol.TField REQUEST_TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("requestType", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -147,7 +151,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
   // isset id assignments
   private static final int __GRANTOPTION_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.GRANTOR,_Fields.GRANTOR_TYPE,_Fields.GRANT_OPTION};
+  private static final _Fields optionals[] = {_Fields.GRANTOR,_Fields.GRANTOR_TYPE,_Fields.GRANT_OPTION};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -605,120 +609,120 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_requestType = true && (isSetRequestType());
-    builder.append(present_requestType);
+    list.add(present_requestType);
     if (present_requestType)
-      builder.append(requestType.getValue());
+      list.add(requestType.getValue());
 
     boolean present_roleName = true && (isSetRoleName());
-    builder.append(present_roleName);
+    list.add(present_roleName);
     if (present_roleName)
-      builder.append(roleName);
+      list.add(roleName);
 
     boolean present_principalName = true && (isSetPrincipalName());
-    builder.append(present_principalName);
+    list.add(present_principalName);
     if (present_principalName)
-      builder.append(principalName);
+      list.add(principalName);
 
     boolean present_principalType = true && (isSetPrincipalType());
-    builder.append(present_principalType);
+    list.add(present_principalType);
     if (present_principalType)
-      builder.append(principalType.getValue());
+      list.add(principalType.getValue());
 
     boolean present_grantor = true && (isSetGrantor());
-    builder.append(present_grantor);
+    list.add(present_grantor);
     if (present_grantor)
-      builder.append(grantor);
+      list.add(grantor);
 
     boolean present_grantorType = true && (isSetGrantorType());
-    builder.append(present_grantorType);
+    list.add(present_grantorType);
     if (present_grantorType)
-      builder.append(grantorType.getValue());
+      list.add(grantorType.getValue());
 
     boolean present_grantOption = true && (isSetGrantOption());
-    builder.append(present_grantOption);
+    list.add(present_grantOption);
     if (present_grantOption)
-      builder.append(grantOption);
+      list.add(grantOption);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GrantRevokeRoleRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GrantRevokeRoleRequest typedOther = (GrantRevokeRoleRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetRequestType()).compareTo(typedOther.isSetRequestType());
+    lastComparison = Boolean.valueOf(isSetRequestType()).compareTo(other.isSetRequestType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRequestType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.requestType, typedOther.requestType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.requestType, other.requestType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(typedOther.isSetRoleName());
+    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(other.isSetRoleName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRoleName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, typedOther.roleName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, other.roleName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(typedOther.isSetPrincipalName());
+    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(other.isSetPrincipalName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, typedOther.principalName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, other.principalName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(typedOther.isSetPrincipalType());
+    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(other.isSetPrincipalType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, typedOther.principalType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, other.principalType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantor()).compareTo(typedOther.isSetGrantor());
+    lastComparison = Boolean.valueOf(isSetGrantor()).compareTo(other.isSetGrantor());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantor()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantor, typedOther.grantor);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantor, other.grantor);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantorType()).compareTo(typedOther.isSetGrantorType());
+    lastComparison = Boolean.valueOf(isSetGrantorType()).compareTo(other.isSetGrantorType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantorType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorType, typedOther.grantorType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorType, other.grantorType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(typedOther.isSetGrantOption());
+    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(other.isSetGrantOption());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantOption()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, typedOther.grantOption);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, other.grantOption);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -847,7 +851,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
         switch (schemeField.id) {
           case 1: // REQUEST_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.requestType = GrantRevokeType.findByValue(iprot.readI32());
+              struct.requestType = org.apache.hadoop.hive.metastore.api.GrantRevokeType.findByValue(iprot.readI32());
               struct.setRequestTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -871,7 +875,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
             break;
           case 4: // PRINCIPAL_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.principalType = PrincipalType.findByValue(iprot.readI32());
+              struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setPrincipalTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -887,7 +891,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
             break;
           case 6: // GRANTOR_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.grantorType = PrincipalType.findByValue(iprot.readI32());
+              struct.grantorType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setGrantorTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1021,7 +1025,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
       TTupleProtocol iprot = (TTupleProtocol) prot;
       BitSet incoming = iprot.readBitSet(7);
       if (incoming.get(0)) {
-        struct.requestType = GrantRevokeType.findByValue(iprot.readI32());
+        struct.requestType = org.apache.hadoop.hive.metastore.api.GrantRevokeType.findByValue(iprot.readI32());
         struct.setRequestTypeIsSet(true);
       }
       if (incoming.get(1)) {
@@ -1033,7 +1037,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
         struct.setPrincipalNameIsSet(true);
       }
       if (incoming.get(3)) {
-        struct.principalType = PrincipalType.findByValue(iprot.readI32());
+        struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setPrincipalTypeIsSet(true);
       }
       if (incoming.get(4)) {
@@ -1041,7 +1045,7 @@ public class GrantRevokeRoleRequest implements org.apache.thrift.TBase<GrantRevo
         struct.setGrantorIsSet(true);
       }
       if (incoming.get(5)) {
-        struct.grantorType = PrincipalType.findByValue(iprot.readI32());
+        struct.grantorType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setGrantorTypeIsSet(true);
       }
       if (incoming.get(6)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleResponse.java
index b9acbb5..c74d0d2 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeRoleResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class GrantRevokeRoleResponse implements org.apache.thrift.TBase<GrantRevokeRoleResponse, GrantRevokeRoleResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class GrantRevokeRoleResponse implements org.apache.thrift.TBase<GrantRevokeRoleResponse, GrantRevokeRoleResponse._Fields>, java.io.Serializable, Cloneable, Comparable<GrantRevokeRoleResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("GrantRevokeRoleResponse");
 
   private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -105,7 +109,7 @@ public class GrantRevokeRoleResponse implements org.apache.thrift.TBase<GrantRev
   // isset id assignments
   private static final int __SUCCESS_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.SUCCESS};
+  private static final _Fields optionals[] = {_Fields.SUCCESS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class GrantRevokeRoleResponse implements org.apache.thrift.TBase<GrantRev
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_success = true && (isSetSuccess());
-    builder.append(present_success);
+    list.add(present_success);
     if (present_success)
-      builder.append(success);
+      list.add(success);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(GrantRevokeRoleResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    GrantRevokeRoleResponse typedOther = (GrantRevokeRoleResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+    lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSuccess()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeType.java
index c949637..f7b4587 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GrantRevokeType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatRequest.java
index 04439b9..9b66b37 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HeartbeatRequest implements org.apache.thrift.TBase<HeartbeatRequest, HeartbeatRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HeartbeatRequest implements org.apache.thrift.TBase<HeartbeatRequest, HeartbeatRequest._Fields>, java.io.Serializable, Cloneable, Comparable<HeartbeatRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HeartbeatRequest");
 
   private static final org.apache.thrift.protocol.TField LOCKID_FIELD_DESC = new org.apache.thrift.protocol.TField("lockid", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -111,7 +115,7 @@ public class HeartbeatRequest implements org.apache.thrift.TBase<HeartbeatReques
   private static final int __LOCKID_ISSET_ID = 0;
   private static final int __TXNID_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.LOCKID,_Fields.TXNID};
+  private static final _Fields optionals[] = {_Fields.LOCKID,_Fields.TXNID};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -275,45 +279,45 @@ public class HeartbeatRequest implements org.apache.thrift.TBase<HeartbeatReques
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lockid = true && (isSetLockid());
-    builder.append(present_lockid);
+    list.add(present_lockid);
     if (present_lockid)
-      builder.append(lockid);
+      list.add(lockid);
 
     boolean present_txnid = true && (isSetTxnid());
-    builder.append(present_txnid);
+    list.add(present_txnid);
     if (present_txnid)
-      builder.append(txnid);
+      list.add(txnid);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HeartbeatRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HeartbeatRequest typedOther = (HeartbeatRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(typedOther.isSetLockid());
+    lastComparison = Boolean.valueOf(isSetLockid()).compareTo(other.isSetLockid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLockid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, typedOther.lockid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lockid, other.lockid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(typedOther.isSetTxnid());
+    lastComparison = Boolean.valueOf(isSetTxnid()).compareTo(other.isSetTxnid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTxnid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, typedOther.txnid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnid, other.txnid);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java
index 062449a..290bbb1 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HeartbeatTxnRangeRequest implements org.apache.thrift.TBase<HeartbeatTxnRangeRequest, HeartbeatTxnRangeRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HeartbeatTxnRangeRequest implements org.apache.thrift.TBase<HeartbeatTxnRangeRequest, HeartbeatTxnRangeRequest._Fields>, java.io.Serializable, Cloneable, Comparable<HeartbeatTxnRangeRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HeartbeatTxnRangeRequest");
 
   private static final org.apache.thrift.protocol.TField MIN_FIELD_DESC = new org.apache.thrift.protocol.TField("min", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -285,45 +289,45 @@ public class HeartbeatTxnRangeRequest implements org.apache.thrift.TBase<Heartbe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_min = true;
-    builder.append(present_min);
+    list.add(present_min);
     if (present_min)
-      builder.append(min);
+      list.add(min);
 
     boolean present_max = true;
-    builder.append(present_max);
+    list.add(present_max);
     if (present_max)
-      builder.append(max);
+      list.add(max);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HeartbeatTxnRangeRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HeartbeatTxnRangeRequest typedOther = (HeartbeatTxnRangeRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetMin()).compareTo(typedOther.isSetMin());
+    lastComparison = Boolean.valueOf(isSetMin()).compareTo(other.isSetMin());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMin()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.min, typedOther.min);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.min, other.min);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMax()).compareTo(typedOther.isSetMax());
+    lastComparison = Boolean.valueOf(isSetMax()).compareTo(other.isSetMax());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMax()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.max, typedOther.max);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.max, other.max);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java
index caf07d6..96f335c 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<HeartbeatTxnRangeResponse, HeartbeatTxnRangeResponse._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<HeartbeatTxnRangeResponse, HeartbeatTxnRangeResponse._Fields>, java.io.Serializable, Cloneable, Comparable<HeartbeatTxnRangeResponse> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HeartbeatTxnRangeResponse");
 
   private static final org.apache.thrift.protocol.TField ABORTED_FIELD_DESC = new org.apache.thrift.protocol.TField("aborted", org.apache.thrift.protocol.TType.SET, (short)1);
@@ -138,17 +142,11 @@ public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<Heartb
    */
   public HeartbeatTxnRangeResponse(HeartbeatTxnRangeResponse other) {
     if (other.isSetAborted()) {
-      Set<Long> __this__aborted = new HashSet<Long>();
-      for (Long other_element : other.aborted) {
-        __this__aborted.add(other_element);
-      }
+      Set<Long> __this__aborted = new HashSet<Long>(other.aborted);
       this.aborted = __this__aborted;
     }
     if (other.isSetNosuch()) {
-      Set<Long> __this__nosuch = new HashSet<Long>();
-      for (Long other_element : other.nosuch) {
-        __this__nosuch.add(other_element);
-      }
+      Set<Long> __this__nosuch = new HashSet<Long>(other.nosuch);
       this.nosuch = __this__nosuch;
     }
   }
@@ -323,45 +321,45 @@ public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<Heartb
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_aborted = true && (isSetAborted());
-    builder.append(present_aborted);
+    list.add(present_aborted);
     if (present_aborted)
-      builder.append(aborted);
+      list.add(aborted);
 
     boolean present_nosuch = true && (isSetNosuch());
-    builder.append(present_nosuch);
+    list.add(present_nosuch);
     if (present_nosuch)
-      builder.append(nosuch);
+      list.add(nosuch);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HeartbeatTxnRangeResponse other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HeartbeatTxnRangeResponse typedOther = (HeartbeatTxnRangeResponse)other;
 
-    lastComparison = Boolean.valueOf(isSetAborted()).compareTo(typedOther.isSetAborted());
+    lastComparison = Boolean.valueOf(isSetAborted()).compareTo(other.isSetAborted());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAborted()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aborted, typedOther.aborted);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aborted, other.aborted);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNosuch()).compareTo(typedOther.isSetNosuch());
+    lastComparison = Boolean.valueOf(isSetNosuch()).compareTo(other.isSetNosuch());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNosuch()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nosuch, typedOther.nosuch);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nosuch, other.nosuch);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -457,11 +455,11 @@ public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<Heartb
               {
                 org.apache.thrift.protocol.TSet _set468 = iprot.readSetBegin();
                 struct.aborted = new HashSet<Long>(2*_set468.size);
-                for (int _i469 = 0; _i469 < _set468.size; ++_i469)
+                long _elem469;
+                for (int _i470 = 0; _i470 < _set468.size; ++_i470)
                 {
-                  long _elem470; // optional
-                  _elem470 = iprot.readI64();
-                  struct.aborted.add(_elem470);
+                  _elem469 = iprot.readI64();
+                  struct.aborted.add(_elem469);
                 }
                 iprot.readSetEnd();
               }
@@ -475,11 +473,11 @@ public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<Heartb
               {
                 org.apache.thrift.protocol.TSet _set471 = iprot.readSetBegin();
                 struct.nosuch = new HashSet<Long>(2*_set471.size);
-                for (int _i472 = 0; _i472 < _set471.size; ++_i472)
+                long _elem472;
+                for (int _i473 = 0; _i473 < _set471.size; ++_i473)
                 {
-                  long _elem473; // optional
-                  _elem473 = iprot.readI64();
-                  struct.nosuch.add(_elem473);
+                  _elem472 = iprot.readI64();
+                  struct.nosuch.add(_elem472);
                 }
                 iprot.readSetEnd();
               }
@@ -564,22 +562,22 @@ public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<Heartb
       {
         org.apache.thrift.protocol.TSet _set478 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, iprot.readI32());
         struct.aborted = new HashSet<Long>(2*_set478.size);
-        for (int _i479 = 0; _i479 < _set478.size; ++_i479)
+        long _elem479;
+        for (int _i480 = 0; _i480 < _set478.size; ++_i480)
         {
-          long _elem480; // optional
-          _elem480 = iprot.readI64();
-          struct.aborted.add(_elem480);
+          _elem479 = iprot.readI64();
+          struct.aborted.add(_elem479);
         }
       }
       struct.setAbortedIsSet(true);
       {
         org.apache.thrift.protocol.TSet _set481 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, iprot.readI32());
         struct.nosuch = new HashSet<Long>(2*_set481.size);
-        for (int _i482 = 0; _i482 < _set481.size; ++_i482)
+        long _elem482;
+        for (int _i483 = 0; _i483 < _set481.size; ++_i483)
         {
-          long _elem483; // optional
-          _elem483 = iprot.readI64();
-          struct.nosuch.add(_elem483);
+          _elem482 = iprot.readI64();
+          struct.nosuch.add(_elem482);
         }
       }
       struct.setNosuchIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectPrivilege.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectPrivilege.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectPrivilege.java
index bd7641d..a490ca0 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectPrivilege.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectPrivilege.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HiveObjectPrivilege implements org.apache.thrift.TBase<HiveObjectPrivilege, HiveObjectPrivilege._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HiveObjectPrivilege implements org.apache.thrift.TBase<HiveObjectPrivilege, HiveObjectPrivilege._Fields>, java.io.Serializable, Cloneable, Comparable<HiveObjectPrivilege> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HiveObjectPrivilege");
 
   private static final org.apache.thrift.protocol.TField HIVE_OBJECT_FIELD_DESC = new org.apache.thrift.protocol.TField("hiveObject", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -411,75 +415,75 @@ public class HiveObjectPrivilege implements org.apache.thrift.TBase<HiveObjectPr
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_hiveObject = true && (isSetHiveObject());
-    builder.append(present_hiveObject);
+    list.add(present_hiveObject);
     if (present_hiveObject)
-      builder.append(hiveObject);
+      list.add(hiveObject);
 
     boolean present_principalName = true && (isSetPrincipalName());
-    builder.append(present_principalName);
+    list.add(present_principalName);
     if (present_principalName)
-      builder.append(principalName);
+      list.add(principalName);
 
     boolean present_principalType = true && (isSetPrincipalType());
-    builder.append(present_principalType);
+    list.add(present_principalType);
     if (present_principalType)
-      builder.append(principalType.getValue());
+      list.add(principalType.getValue());
 
     boolean present_grantInfo = true && (isSetGrantInfo());
-    builder.append(present_grantInfo);
+    list.add(present_grantInfo);
     if (present_grantInfo)
-      builder.append(grantInfo);
+      list.add(grantInfo);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HiveObjectPrivilege other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HiveObjectPrivilege typedOther = (HiveObjectPrivilege)other;
 
-    lastComparison = Boolean.valueOf(isSetHiveObject()).compareTo(typedOther.isSetHiveObject());
+    lastComparison = Boolean.valueOf(isSetHiveObject()).compareTo(other.isSetHiveObject());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHiveObject()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hiveObject, typedOther.hiveObject);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hiveObject, other.hiveObject);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(typedOther.isSetPrincipalName());
+    lastComparison = Boolean.valueOf(isSetPrincipalName()).compareTo(other.isSetPrincipalName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, typedOther.principalName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalName, other.principalName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(typedOther.isSetPrincipalType());
+    lastComparison = Boolean.valueOf(isSetPrincipalType()).compareTo(other.isSetPrincipalType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrincipalType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, typedOther.principalType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.principalType, other.principalType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantInfo()).compareTo(typedOther.isSetGrantInfo());
+    lastComparison = Boolean.valueOf(isSetGrantInfo()).compareTo(other.isSetGrantInfo());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantInfo()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantInfo, typedOther.grantInfo);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantInfo, other.grantInfo);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -603,7 +607,7 @@ public class HiveObjectPrivilege implements org.apache.thrift.TBase<HiveObjectPr
             break;
           case 3: // PRINCIPAL_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.principalType = PrincipalType.findByValue(iprot.readI32());
+              struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setPrincipalTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -710,7 +714,7 @@ public class HiveObjectPrivilege implements org.apache.thrift.TBase<HiveObjectPr
         struct.setPrincipalNameIsSet(true);
       }
       if (incoming.get(2)) {
-        struct.principalType = PrincipalType.findByValue(iprot.readI32());
+        struct.principalType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setPrincipalTypeIsSet(true);
       }
       if (incoming.get(3)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java
index b22b211..9de47ad 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, HiveObjectRef._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, HiveObjectRef._Fields>, java.io.Serializable, Cloneable, Comparable<HiveObjectRef> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("HiveObjectRef");
 
   private static final org.apache.thrift.protocol.TField OBJECT_TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("objectType", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -177,10 +181,7 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
       this.objectName = other.objectName;
     }
     if (other.isSetPartValues()) {
-      List<String> __this__partValues = new ArrayList<String>();
-      for (String other_element : other.partValues) {
-        __this__partValues.add(other_element);
-      }
+      List<String> __this__partValues = new ArrayList<String>(other.partValues);
       this.partValues = __this__partValues;
     }
     if (other.isSetColumnName()) {
@@ -489,90 +490,90 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_objectType = true && (isSetObjectType());
-    builder.append(present_objectType);
+    list.add(present_objectType);
     if (present_objectType)
-      builder.append(objectType.getValue());
+      list.add(objectType.getValue());
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_objectName = true && (isSetObjectName());
-    builder.append(present_objectName);
+    list.add(present_objectName);
     if (present_objectName)
-      builder.append(objectName);
+      list.add(objectName);
 
     boolean present_partValues = true && (isSetPartValues());
-    builder.append(present_partValues);
+    list.add(present_partValues);
     if (present_partValues)
-      builder.append(partValues);
+      list.add(partValues);
 
     boolean present_columnName = true && (isSetColumnName());
-    builder.append(present_columnName);
+    list.add(present_columnName);
     if (present_columnName)
-      builder.append(columnName);
+      list.add(columnName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(HiveObjectRef other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    HiveObjectRef typedOther = (HiveObjectRef)other;
 
-    lastComparison = Boolean.valueOf(isSetObjectType()).compareTo(typedOther.isSetObjectType());
+    lastComparison = Boolean.valueOf(isSetObjectType()).compareTo(other.isSetObjectType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetObjectType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectType, typedOther.objectType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectType, other.objectType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetObjectName()).compareTo(typedOther.isSetObjectName());
+    lastComparison = Boolean.valueOf(isSetObjectName()).compareTo(other.isSetObjectName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetObjectName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectName, typedOther.objectName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectName, other.objectName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartValues()).compareTo(typedOther.isSetPartValues());
+    lastComparison = Boolean.valueOf(isSetPartValues()).compareTo(other.isSetPartValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partValues, typedOther.partValues);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partValues, other.partValues);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(typedOther.isSetColumnName());
+    lastComparison = Boolean.valueOf(isSetColumnName()).compareTo(other.isSetColumnName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColumnName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, typedOther.columnName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columnName, other.columnName);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -681,7 +682,7 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
         switch (schemeField.id) {
           case 1: // OBJECT_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.objectType = HiveObjectType.findByValue(iprot.readI32());
+              struct.objectType = org.apache.hadoop.hive.metastore.api.HiveObjectType.findByValue(iprot.readI32());
               struct.setObjectTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -708,11 +709,11 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
               {
                 org.apache.thrift.protocol.TList _list8 = iprot.readListBegin();
                 struct.partValues = new ArrayList<String>(_list8.size);
-                for (int _i9 = 0; _i9 < _list8.size; ++_i9)
+                String _elem9;
+                for (int _i10 = 0; _i10 < _list8.size; ++_i10)
                 {
-                  String _elem10; // optional
-                  _elem10 = iprot.readString();
-                  struct.partValues.add(_elem10);
+                  _elem9 = iprot.readString();
+                  struct.partValues.add(_elem9);
                 }
                 iprot.readListEnd();
               }
@@ -836,7 +837,7 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
       TTupleProtocol iprot = (TTupleProtocol) prot;
       BitSet incoming = iprot.readBitSet(5);
       if (incoming.get(0)) {
-        struct.objectType = HiveObjectType.findByValue(iprot.readI32());
+        struct.objectType = org.apache.hadoop.hive.metastore.api.HiveObjectType.findByValue(iprot.readI32());
         struct.setObjectTypeIsSet(true);
       }
       if (incoming.get(1)) {
@@ -851,11 +852,11 @@ public class HiveObjectRef implements org.apache.thrift.TBase<HiveObjectRef, Hiv
         {
           org.apache.thrift.protocol.TList _list13 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.partValues = new ArrayList<String>(_list13.size);
-          for (int _i14 = 0; _i14 < _list13.size; ++_i14)
+          String _elem14;
+          for (int _i15 = 0; _i15 < _list13.size; ++_i15)
           {
-            String _elem15; // optional
-            _elem15 = iprot.readString();
-            struct.partValues.add(_elem15);
+            _elem14 = iprot.readString();
+            struct.partValues.add(_elem14);
           }
         }
         struct.setPartValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectType.java
index 995331e..427930f 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Index.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Index.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Index.java
index cb3a435..763c7cd 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Index.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Index.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, java.io.Serializable, Cloneable, Comparable<Index> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Index");
 
   private static final org.apache.thrift.protocol.TField INDEX_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("indexName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -238,18 +242,7 @@ public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, jav
       this.sd = new StorageDescriptor(other.sd);
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     this.deferredRebuild = other.deferredRebuild;
@@ -774,165 +767,165 @@ public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, jav
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_indexName = true && (isSetIndexName());
-    builder.append(present_indexName);
+    list.add(present_indexName);
     if (present_indexName)
-      builder.append(indexName);
+      list.add(indexName);
 
     boolean present_indexHandlerClass = true && (isSetIndexHandlerClass());
-    builder.append(present_indexHandlerClass);
+    list.add(present_indexHandlerClass);
     if (present_indexHandlerClass)
-      builder.append(indexHandlerClass);
+      list.add(indexHandlerClass);
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_origTableName = true && (isSetOrigTableName());
-    builder.append(present_origTableName);
+    list.add(present_origTableName);
     if (present_origTableName)
-      builder.append(origTableName);
+      list.add(origTableName);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_lastAccessTime = true;
-    builder.append(present_lastAccessTime);
+    list.add(present_lastAccessTime);
     if (present_lastAccessTime)
-      builder.append(lastAccessTime);
+      list.add(lastAccessTime);
 
     boolean present_indexTableName = true && (isSetIndexTableName());
-    builder.append(present_indexTableName);
+    list.add(present_indexTableName);
     if (present_indexTableName)
-      builder.append(indexTableName);
+      list.add(indexTableName);
 
     boolean present_sd = true && (isSetSd());
-    builder.append(present_sd);
+    list.add(present_sd);
     if (present_sd)
-      builder.append(sd);
+      list.add(sd);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_deferredRebuild = true;
-    builder.append(present_deferredRebuild);
+    list.add(present_deferredRebuild);
     if (present_deferredRebuild)
-      builder.append(deferredRebuild);
+      list.add(deferredRebuild);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Index other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Index typedOther = (Index)other;
 
-    lastComparison = Boolean.valueOf(isSetIndexName()).compareTo(typedOther.isSetIndexName());
+    lastComparison = Boolean.valueOf(isSetIndexName()).compareTo(other.isSetIndexName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIndexName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexName, typedOther.indexName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexName, other.indexName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetIndexHandlerClass()).compareTo(typedOther.isSetIndexHandlerClass());
+    lastComparison = Boolean.valueOf(isSetIndexHandlerClass()).compareTo(other.isSetIndexHandlerClass());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIndexHandlerClass()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexHandlerClass, typedOther.indexHandlerClass);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexHandlerClass, other.indexHandlerClass);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOrigTableName()).compareTo(typedOther.isSetOrigTableName());
+    lastComparison = Boolean.valueOf(isSetOrigTableName()).compareTo(other.isSetOrigTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOrigTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.origTableName, typedOther.origTableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.origTableName, other.origTableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(typedOther.isSetLastAccessTime());
+    lastComparison = Boolean.valueOf(isSetLastAccessTime()).compareTo(other.isSetLastAccessTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLastAccessTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, typedOther.lastAccessTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lastAccessTime, other.lastAccessTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetIndexTableName()).compareTo(typedOther.isSetIndexTableName());
+    lastComparison = Boolean.valueOf(isSetIndexTableName()).compareTo(other.isSetIndexTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIndexTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexTableName, typedOther.indexTableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.indexTableName, other.indexTableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSd()).compareTo(typedOther.isSetSd());
+    lastComparison = Boolean.valueOf(isSetSd()).compareTo(other.isSetSd());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSd()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, typedOther.sd);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sd, other.sd);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDeferredRebuild()).compareTo(typedOther.isSetDeferredRebuild());
+    lastComparison = Boolean.valueOf(isSetDeferredRebuild()).compareTo(other.isSetDeferredRebuild());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDeferredRebuild()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.deferredRebuild, typedOther.deferredRebuild);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.deferredRebuild, other.deferredRebuild);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -1142,13 +1135,13 @@ public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, jav
               {
                 org.apache.thrift.protocol.TMap _map260 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map260.size);
-                for (int _i261 = 0; _i261 < _map260.size; ++_i261)
+                String _key261;
+                String _val262;
+                for (int _i263 = 0; _i263 < _map260.size; ++_i263)
                 {
-                  String _key262; // required
-                  String _val263; // required
-                  _key262 = iprot.readString();
-                  _val263 = iprot.readString();
-                  struct.parameters.put(_key262, _val263);
+                  _key261 = iprot.readString();
+                  _val262 = iprot.readString();
+                  struct.parameters.put(_key261, _val262);
                 }
                 iprot.readMapEnd();
               }
@@ -1359,13 +1352,13 @@ public class Index implements org.apache.thrift.TBase<Index, Index._Fields>, jav
         {
           org.apache.thrift.protocol.TMap _map266 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map266.size);
-          for (int _i267 = 0; _i267 < _map266.size; ++_i267)
+          String _key267;
+          String _val268;
+          for (int _i269 = 0; _i269 < _map266.size; ++_i269)
           {
-            String _key268; // required
-            String _val269; // required
-            _key268 = iprot.readString();
-            _val269 = iprot.readString();
-            struct.parameters.put(_key268, _val269);
+            _key267 = iprot.readString();
+            _val268 = iprot.readString();
+            struct.parameters.put(_key267, _val268);
           }
         }
         struct.setParametersIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/IndexAlreadyExistsException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/IndexAlreadyExistsException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/IndexAlreadyExistsException.java
index f90a65d..817d873 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/IndexAlreadyExistsException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/IndexAlreadyExistsException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class IndexAlreadyExistsException extends TException implements org.apache.thrift.TBase<IndexAlreadyExistsException, IndexAlreadyExistsException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class IndexAlreadyExistsException extends TException implements org.apache.thrift.TBase<IndexAlreadyExistsException, IndexAlreadyExistsException._Fields>, java.io.Serializable, Cloneable, Comparable<IndexAlreadyExistsException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IndexAlreadyExistsException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class IndexAlreadyExistsException extends TException implements org.apach
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(IndexAlreadyExistsException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    IndexAlreadyExistsException typedOther = (IndexAlreadyExistsException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }


[31/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php b/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
index 8342f6b..43e0878 100644
--- a/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
+++ b/metastore/src/gen/thrift/gen-php/metastore/ThriftHiveMetastore.php
@@ -1,7 +1,7 @@
 <?php
 namespace metastore;
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -12,132 +12,995 @@ use Thrift\Type\TMessageType;
 use Thrift\Exception\TException;
 use Thrift\Exception\TProtocolException;
 use Thrift\Protocol\TProtocol;
+use Thrift\Protocol\TBinaryProtocolAccelerated;
 use Thrift\Exception\TApplicationException;
 
 
+/**
+ * This interface is live.
+ */
 interface ThriftHiveMetastoreIf extends \FacebookServiceIf {
+  /**
+   * @param string $key
+   * @return string
+   * @throws \metastore\MetaException
+   */
   public function getMetaConf($key);
+  /**
+   * @param string $key
+   * @param string $value
+   * @throws \metastore\MetaException
+   */
   public function setMetaConf($key, $value);
+  /**
+   * @param \metastore\Database $database
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   */
   public function create_database(\metastore\Database $database);
+  /**
+   * @param string $name
+   * @return \metastore\Database
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_database($name);
+  /**
+   * @param string $name
+   * @param bool $deleteData
+   * @param bool $cascade
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function drop_database($name, $deleteData, $cascade);
+  /**
+   * @param string $pattern
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_databases($pattern);
+  /**
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_all_databases();
+  /**
+   * @param string $dbname
+   * @param \metastore\Database $db
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function alter_database($dbname, \metastore\Database $db);
+  /**
+   * @param string $name
+   * @return \metastore\Type
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_type($name);
+  /**
+   * @param \metastore\Type $type
+   * @return bool
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   */
   public function create_type(\metastore\Type $type);
+  /**
+   * @param string $type
+   * @return bool
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function drop_type($type);
+  /**
+   * @param string $name
+   * @return array
+   * @throws \metastore\MetaException
+   */
   public function get_type_all($name);
+  /**
+   * @param string $db_name
+   * @param string $table_name
+   * @return \metastore\FieldSchema[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownDBException
+   */
   public function get_fields($db_name, $table_name);
+  /**
+   * @param string $db_name
+   * @param string $table_name
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return \metastore\FieldSchema[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownDBException
+   */
   public function get_fields_with_environment_context($db_name, $table_name, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $table_name
+   * @return \metastore\FieldSchema[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownDBException
+   */
   public function get_schema($db_name, $table_name);
+  /**
+   * @param string $db_name
+   * @param string $table_name
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return \metastore\FieldSchema[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownDBException
+   */
   public function get_schema_with_environment_context($db_name, $table_name, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param \metastore\Table $tbl
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function create_table(\metastore\Table $tbl);
+  /**
+   * @param \metastore\Table $tbl
+   * @param \metastore\EnvironmentContext $environment_context
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function create_table_with_environment_context(\metastore\Table $tbl, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $dbname
+   * @param string $name
+   * @param bool $deleteData
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_table($dbname, $name, $deleteData);
+  /**
+   * @param string $dbname
+   * @param string $name
+   * @param bool $deleteData
+   * @param \metastore\EnvironmentContext $environment_context
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_table_with_environment_context($dbname, $name, $deleteData, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $pattern
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_tables($db_name, $pattern);
+  /**
+   * @param string $db_name
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_all_tables($db_name);
+  /**
+   * @param string $dbname
+   * @param string $tbl_name
+   * @return \metastore\Table
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_table($dbname, $tbl_name);
-  public function get_table_objects_by_name($dbname, $tbl_names);
+  /**
+   * @param string $dbname
+   * @param string[] $tbl_names
+   * @return \metastore\Table[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\UnknownDBException
+   */
+  public function get_table_objects_by_name($dbname, array $tbl_names);
+  /**
+   * @param string $dbname
+   * @param string $filter
+   * @param int $max_tables
+   * @return string[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\UnknownDBException
+   */
   public function get_table_names_by_filter($dbname, $filter, $max_tables);
+  /**
+   * @param string $dbname
+   * @param string $tbl_name
+   * @param \metastore\Table $new_tbl
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_table($dbname, $tbl_name, \metastore\Table $new_tbl);
+  /**
+   * @param string $dbname
+   * @param string $tbl_name
+   * @param \metastore\Table $new_tbl
+   * @param \metastore\EnvironmentContext $environment_context
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_table_with_environment_context($dbname, $tbl_name, \metastore\Table $new_tbl, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $dbname
+   * @param string $tbl_name
+   * @param \metastore\Table $new_tbl
+   * @param bool $cascade
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_table_with_cascade($dbname, $tbl_name, \metastore\Table $new_tbl, $cascade);
+  /**
+   * @param \metastore\Partition $new_part
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function add_partition(\metastore\Partition $new_part);
+  /**
+   * @param \metastore\Partition $new_part
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function add_partition_with_environment_context(\metastore\Partition $new_part, \metastore\EnvironmentContext $environment_context);
-  public function add_partitions($new_parts);
-  public function add_partitions_pspec($new_parts);
-  public function append_partition($db_name, $tbl_name, $part_vals);
+  /**
+   * @param \metastore\Partition[] $new_parts
+   * @return int
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
+  public function add_partitions(array $new_parts);
+  /**
+   * @param \metastore\PartitionSpec[] $new_parts
+   * @return int
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
+  public function add_partitions_pspec(array $new_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
+  public function append_partition($db_name, $tbl_name, array $part_vals);
+  /**
+   * @param \metastore\AddPartitionsRequest $request
+   * @return \metastore\AddPartitionsResult
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function add_partitions_req(\metastore\AddPartitionsRequest $request);
-  public function append_partition_with_environment_context($db_name, $tbl_name, $part_vals, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
+  public function append_partition_with_environment_context($db_name, $tbl_name, array $part_vals, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function append_partition_by_name($db_name, $tbl_name, $part_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return \metastore\Partition
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function append_partition_by_name_with_environment_context($db_name, $tbl_name, $part_name, \metastore\EnvironmentContext $environment_context);
-  public function drop_partition($db_name, $tbl_name, $part_vals, $deleteData);
-  public function drop_partition_with_environment_context($db_name, $tbl_name, $part_vals, $deleteData, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param bool $deleteData
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
+  public function drop_partition($db_name, $tbl_name, array $part_vals, $deleteData);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param bool $deleteData
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
+  public function drop_partition_with_environment_context($db_name, $tbl_name, array $part_vals, $deleteData, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @param bool $deleteData
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_partition_by_name($db_name, $tbl_name, $part_name, $deleteData);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @param bool $deleteData
+   * @param \metastore\EnvironmentContext $environment_context
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_partition_by_name_with_environment_context($db_name, $tbl_name, $part_name, $deleteData, \metastore\EnvironmentContext $environment_context);
+  /**
+   * @param \metastore\DropPartitionsRequest $req
+   * @return \metastore\DropPartitionsResult
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_partitions_req(\metastore\DropPartitionsRequest $req);
-  public function get_partition($db_name, $tbl_name, $part_vals);
-  public function exchange_partition($partitionSpecs, $source_db, $source_table_name, $dest_db, $dest_table_name);
-  public function get_partition_with_auth($db_name, $tbl_name, $part_vals, $user_name, $group_names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @return \metastore\Partition
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
+  public function get_partition($db_name, $tbl_name, array $part_vals);
+  /**
+   * @param array $partitionSpecs
+   * @param string $source_db
+   * @param string $source_table_name
+   * @param string $dest_db
+   * @param string $dest_table_name
+   * @return \metastore\Partition
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\InvalidInputException
+   */
+  public function exchange_partition(array $partitionSpecs, $source_db, $source_table_name, $dest_db, $dest_table_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param string $user_name
+   * @param string[] $group_names
+   * @return \metastore\Partition
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
+  public function get_partition_with_auth($db_name, $tbl_name, array $part_vals, $user_name, array $group_names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @return \metastore\Partition
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_partition_by_name($db_name, $tbl_name, $part_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_parts
+   * @return \metastore\Partition[]
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_partitions($db_name, $tbl_name, $max_parts);
-  public function get_partitions_with_auth($db_name, $tbl_name, $max_parts, $user_name, $group_names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_parts
+   * @param string $user_name
+   * @param string[] $group_names
+   * @return \metastore\Partition[]
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
+  public function get_partitions_with_auth($db_name, $tbl_name, $max_parts, $user_name, array $group_names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_parts
+   * @return \metastore\PartitionSpec[]
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_partitions_pspec($db_name, $tbl_name, $max_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_parts
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_partition_names($db_name, $tbl_name, $max_parts);
-  public function get_partitions_ps($db_name, $tbl_name, $part_vals, $max_parts);
-  public function get_partitions_ps_with_auth($db_name, $tbl_name, $part_vals, $max_parts, $user_name, $group_names);
-  public function get_partition_names_ps($db_name, $tbl_name, $part_vals, $max_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param int $max_parts
+   * @return \metastore\Partition[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
+  public function get_partitions_ps($db_name, $tbl_name, array $part_vals, $max_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param int $max_parts
+   * @param string $user_name
+   * @param string[] $group_names
+   * @return \metastore\Partition[]
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
+  public function get_partitions_ps_with_auth($db_name, $tbl_name, array $part_vals, $max_parts, $user_name, array $group_names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param int $max_parts
+   * @return string[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
+  public function get_partition_names_ps($db_name, $tbl_name, array $part_vals, $max_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $filter
+   * @param int $max_parts
+   * @return \metastore\Partition[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_partitions_by_filter($db_name, $tbl_name, $filter, $max_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $filter
+   * @param int $max_parts
+   * @return \metastore\PartitionSpec[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_part_specs_by_filter($db_name, $tbl_name, $filter, $max_parts);
+  /**
+   * @param \metastore\PartitionsByExprRequest $req
+   * @return \metastore\PartitionsByExprResult
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_partitions_by_expr(\metastore\PartitionsByExprRequest $req);
-  public function get_partitions_by_names($db_name, $tbl_name, $names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $names
+   * @return \metastore\Partition[]
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
+  public function get_partitions_by_names($db_name, $tbl_name, array $names);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param \metastore\Partition $new_part
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_partition($db_name, $tbl_name, \metastore\Partition $new_part);
-  public function alter_partitions($db_name, $tbl_name, $new_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param \metastore\Partition[] $new_parts
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
+  public function alter_partitions($db_name, $tbl_name, array $new_parts);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param \metastore\Partition $new_part
+   * @param \metastore\EnvironmentContext $environment_context
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_partition_with_environment_context($db_name, $tbl_name, \metastore\Partition $new_part, \metastore\EnvironmentContext $environment_context);
-  public function rename_partition($db_name, $tbl_name, $part_vals, \metastore\Partition $new_part);
-  public function partition_name_has_valid_characters($part_vals, $throw_exception);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string[] $part_vals
+   * @param \metastore\Partition $new_part
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
+  public function rename_partition($db_name, $tbl_name, array $part_vals, \metastore\Partition $new_part);
+  /**
+   * @param string[] $part_vals
+   * @param bool $throw_exception
+   * @return bool
+   * @throws \metastore\MetaException
+   */
+  public function partition_name_has_valid_characters(array $part_vals, $throw_exception);
+  /**
+   * @param string $name
+   * @param string $defaultValue
+   * @return string
+   * @throws \metastore\ConfigValSecurityException
+   */
   public function get_config_value($name, $defaultValue);
+  /**
+   * @param string $part_name
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function partition_name_to_vals($part_name);
+  /**
+   * @param string $part_name
+   * @return array
+   * @throws \metastore\MetaException
+   */
   public function partition_name_to_spec($part_name);
-  public function markPartitionForEvent($db_name, $tbl_name, $part_vals, $eventType);
-  public function isPartitionMarkedForEvent($db_name, $tbl_name, $part_vals, $eventType);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param array $part_vals
+   * @param int $eventType
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\UnknownDBException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownPartitionException
+   * @throws \metastore\InvalidPartitionException
+   */
+  public function markPartitionForEvent($db_name, $tbl_name, array $part_vals, $eventType);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param array $part_vals
+   * @param int $eventType
+   * @return bool
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\UnknownDBException
+   * @throws \metastore\UnknownTableException
+   * @throws \metastore\UnknownPartitionException
+   * @throws \metastore\InvalidPartitionException
+   */
+  public function isPartitionMarkedForEvent($db_name, $tbl_name, array $part_vals, $eventType);
+  /**
+   * @param \metastore\Index $new_index
+   * @param \metastore\Table $index_table
+   * @return \metastore\Index
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\MetaException
+   */
   public function add_index(\metastore\Index $new_index, \metastore\Table $index_table);
+  /**
+   * @param string $dbname
+   * @param string $base_tbl_name
+   * @param string $idx_name
+   * @param \metastore\Index $new_idx
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_index($dbname, $base_tbl_name, $idx_name, \metastore\Index $new_idx);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $index_name
+   * @param bool $deleteData
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_index_by_name($db_name, $tbl_name, $index_name, $deleteData);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $index_name
+   * @return \metastore\Index
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_index_by_name($db_name, $tbl_name, $index_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_indexes
+   * @return \metastore\Index[]
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_indexes($db_name, $tbl_name, $max_indexes);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param int $max_indexes
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_index_names($db_name, $tbl_name, $max_indexes);
+  /**
+   * @param \metastore\ColumnStatistics $stats_obj
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidInputException
+   */
   public function update_table_column_statistics(\metastore\ColumnStatistics $stats_obj);
+  /**
+   * @param \metastore\ColumnStatistics $stats_obj
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidInputException
+   */
   public function update_partition_column_statistics(\metastore\ColumnStatistics $stats_obj);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $col_name
+   * @return \metastore\ColumnStatistics
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidInputException
+   * @throws \metastore\InvalidObjectException
+   */
   public function get_table_column_statistics($db_name, $tbl_name, $col_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @param string $col_name
+   * @return \metastore\ColumnStatistics
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidInputException
+   * @throws \metastore\InvalidObjectException
+   */
   public function get_partition_column_statistics($db_name, $tbl_name, $part_name, $col_name);
+  /**
+   * @param \metastore\TableStatsRequest $request
+   * @return \metastore\TableStatsResult
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_table_statistics_req(\metastore\TableStatsRequest $request);
+  /**
+   * @param \metastore\PartitionsStatsRequest $request
+   * @return \metastore\PartitionsStatsResult
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_partitions_statistics_req(\metastore\PartitionsStatsRequest $request);
+  /**
+   * @param \metastore\PartitionsStatsRequest $request
+   * @return \metastore\AggrStats
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function get_aggr_stats_for(\metastore\PartitionsStatsRequest $request);
+  /**
+   * @param \metastore\SetPartitionsStatsRequest $request
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidInputException
+   */
   public function set_aggr_stats_for(\metastore\SetPartitionsStatsRequest $request);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $part_name
+   * @param string $col_name
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\InvalidInputException
+   */
   public function delete_partition_column_statistics($db_name, $tbl_name, $part_name, $col_name);
+  /**
+   * @param string $db_name
+   * @param string $tbl_name
+   * @param string $col_name
+   * @return bool
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\InvalidInputException
+   */
   public function delete_table_column_statistics($db_name, $tbl_name, $col_name);
+  /**
+   * @param \metastore\Function $func
+   * @throws \metastore\AlreadyExistsException
+   * @throws \metastore\InvalidObjectException
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function create_function(\metastore\Function $func);
+  /**
+   * @param string $dbName
+   * @param string $funcName
+   * @throws \metastore\NoSuchObjectException
+   * @throws \metastore\MetaException
+   */
   public function drop_function($dbName, $funcName);
+  /**
+   * @param string $dbName
+   * @param string $funcName
+   * @param \metastore\Function $newFunc
+   * @throws \metastore\InvalidOperationException
+   * @throws \metastore\MetaException
+   */
   public function alter_function($dbName, $funcName, \metastore\Function $newFunc);
+  /**
+   * @param string $dbName
+   * @param string $pattern
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_functions($dbName, $pattern);
+  /**
+   * @param string $dbName
+   * @param string $funcName
+   * @return \metastore\Function
+   * @throws \metastore\MetaException
+   * @throws \metastore\NoSuchObjectException
+   */
   public function get_function($dbName, $funcName);
+  /**
+   * @param \metastore\Role $role
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function create_role(\metastore\Role $role);
+  /**
+   * @param string $role_name
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function drop_role($role_name);
+  /**
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
   public function get_role_names();
+  /**
+   * @param string $role_name
+   * @param string $principal_name
+   * @param int $principal_type
+   * @param string $grantor
+   * @param int $grantorType
+   * @param bool $grant_option
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function grant_role($role_name, $principal_name, $principal_type, $grantor, $grantorType, $grant_option);
+  /**
+   * @param string $role_name
+   * @param string $principal_name
+   * @param int $principal_type
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function revoke_role($role_name, $principal_name, $principal_type);
+  /**
+   * @param string $principal_name
+   * @param int $principal_type
+   * @return \metastore\Role[]
+   * @throws \metastore\MetaException
+   */
   public function list_roles($principal_name, $principal_type);
+  /**
+   * @param \metastore\GrantRevokeRoleRequest $request
+   * @return \metastore\GrantRevokeRoleResponse
+   * @throws \metastore\MetaException
+   */
   public function grant_revoke_role(\metastore\GrantRevokeRoleRequest $request);
+  /**
+   * @param \metastore\GetPrincipalsInRoleRequest $request
+   * @return \metastore\GetPrincipalsInRoleResponse
+   * @throws \metastore\MetaException
+   */
   public function get_principals_in_role(\metastore\GetPrincipalsInRoleRequest $request);
+  /**
+   * @param \metastore\GetRoleGrantsForPrincipalRequest $request
+   * @return \metastore\GetRoleGrantsForPrincipalResponse
+   * @throws \metastore\MetaException
+   */
   public function get_role_grants_for_principal(\metastore\GetRoleGrantsForPrincipalRequest $request);
-  public function get_privilege_set(\metastore\HiveObjectRef $hiveObject, $user_name, $group_names);
+  /**
+   * @param \metastore\HiveObjectRef $hiveObject
+   * @param string $user_name
+   * @param string[] $group_names
+   * @return \metastore\PrincipalPrivilegeSet
+   * @throws \metastore\MetaException
+   */
+  public function get_privilege_set(\metastore\HiveObjectRef $hiveObject, $user_name, array $group_names);
+  /**
+   * @param string $principal_name
+   * @param int $principal_type
+   * @param \metastore\HiveObjectRef $hiveObject
+   * @return \metastore\HiveObjectPrivilege[]
+   * @throws \metastore\MetaException
+   */
   public function list_privileges($principal_name, $principal_type, \metastore\HiveObjectRef $hiveObject);
+  /**
+   * @param \metastore\PrivilegeBag $privileges
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function grant_privileges(\metastore\PrivilegeBag $privileges);
+  /**
+   * @param \metastore\PrivilegeBag $privileges
+   * @return bool
+   * @throws \metastore\MetaException
+   */
   public function revoke_privileges(\metastore\PrivilegeBag $privileges);
+  /**
+   * @param \metastore\GrantRevokePrivilegeRequest $request
+   * @return \metastore\GrantRevokePrivilegeResponse
+   * @throws \metastore\MetaException
+   */
   public function grant_revoke_privileges(\metastore\GrantRevokePrivilegeRequest $request);
-  public function set_ugi($user_name, $group_names);
+  /**
+   * @param string $user_name
+   * @param string[] $group_names
+   * @return string[]
+   * @throws \metastore\MetaException
+   */
+  public function set_ugi($user_name, array $group_names);
+  /**
+   * @param string $token_owner
+   * @param string $renewer_kerberos_principal_name
+   * @return string
+   * @throws \metastore\MetaException
+   */
   public function get_delegation_token($token_owner, $renewer_kerberos_principal_name);
+  /**
+   * @param string $token_str_form
+   * @return int
+   * @throws \metastore\MetaException
+   */
   public function renew_delegation_token($token_str_form);
+  /**
+   * @param string $token_str_form
+   * @throws \metastore\MetaException
+   */
   public function cancel_delegation_token($token_str_form);
+  /**
+   * @return \metastore\GetOpenTxnsResponse
+   */
   public function get_open_txns();
+  /**
+   * @return \metastore\GetOpenTxnsInfoResponse
+   */
   public function get_open_txns_info();
+  /**
+   * @param \metastore\OpenTxnRequest $rqst
+   * @return \metastore\OpenTxnsResponse
+   */
   public function open_txns(\metastore\OpenTxnRequest $rqst);
+  /**
+   * @param \metastore\AbortTxnRequest $rqst
+   * @throws \metastore\NoSuchTxnException
+   */
   public function abort_txn(\metastore\AbortTxnRequest $rqst);
+  /**
+   * @param \metastore\CommitTxnRequest $rqst
+   * @throws \metastore\NoSuchTxnException
+   * @throws \metastore\TxnAbortedException
+   */
   public function commit_txn(\metastore\CommitTxnRequest $rqst);
+  /**
+   * @param \metastore\LockRequest $rqst
+   * @return \metastore\LockResponse
+   * @throws \metastore\NoSuchTxnException
+   * @throws \metastore\TxnAbortedException
+   */
   public function lock(\metastore\LockRequest $rqst);
+  /**
+   * @param \metastore\CheckLockRequest $rqst
+   * @return \metastore\LockResponse
+   * @throws \metastore\NoSuchTxnException
+   * @throws \metastore\TxnAbortedException
+   * @throws \metastore\NoSuchLockException
+   */
   public function check_lock(\metastore\CheckLockRequest $rqst);
+  /**
+   * @param \metastore\UnlockRequest $rqst
+   * @throws \metastore\NoSuchLockException
+   * @throws \metastore\TxnOpenException
+   */
   public function unlock(\metastore\UnlockRequest $rqst);
+  /**
+   * @param \metastore\ShowLocksRequest $rqst
+   * @return \metastore\ShowLocksResponse
+   */
   public function show_locks(\metastore\ShowLocksRequest $rqst);
+  /**
+   * @param \metastore\HeartbeatRequest $ids
+   * @throws \metastore\NoSuchLockException
+   * @throws \metastore\NoSuchTxnException
+   * @throws \metastore\TxnAbortedException
+   */
   public function heartbeat(\metastore\HeartbeatRequest $ids);
+  /**
+   * @param \metastore\HeartbeatTxnRangeRequest $txns
+   * @return \metastore\HeartbeatTxnRangeResponse
+   */
   public function heartbeat_txn_range(\metastore\HeartbeatTxnRangeRequest $txns);
+  /**
+   * @param \metastore\CompactionRequest $rqst
+   */
   public function compact(\metastore\CompactionRequest $rqst);
+  /**
+   * @param \metastore\ShowCompactRequest $rqst
+   * @return \metastore\ShowCompactResponse
+   */
   public function show_compact(\metastore\ShowCompactRequest $rqst);
+  /**
+   * @param \metastore\AddDynamicPartitions $rqst
+   * @throws \metastore\NoSuchTxnException
+   * @throws \metastore\TxnAbortedException
+   */
   public function add_dynamic_partitions(\metastore\AddDynamicPartitions $rqst);
+  /**
+   * @param \metastore\NotificationEventRequest $rqst
+   * @return \metastore\NotificationEventResponse
+   */
   public function get_next_notification(\metastore\NotificationEventRequest $rqst);
+  /**
+   * @return \metastore\CurrentNotificationEventId
+   */
   public function get_current_notificationEventId();
+  /**
+   * @param \metastore\FireEventRequest $rqst
+   * @return \metastore\FireEventResponse
+   */
   public function fire_listener_event(\metastore\FireEventRequest $rqst);
 }
 
@@ -156,7 +1019,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_getMetaConf_args();
     $args->key = $key;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'getMetaConf', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -172,7 +1035,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_getMetaConf()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_getMetaConf_result', $this->input_->isStrictRead());
     else
     {
@@ -211,7 +1074,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_setMetaConf_args();
     $args->key = $key;
     $args->value = $value;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'setMetaConf', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -227,7 +1090,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_setMetaConf()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_setMetaConf_result', $this->input_->isStrictRead());
     else
     {
@@ -262,7 +1125,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_create_database_args();
     $args->database = $database;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'create_database', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -278,7 +1141,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_create_database()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_create_database_result', $this->input_->isStrictRead());
     else
     {
@@ -319,7 +1182,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_get_database_args();
     $args->name = $name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_database', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -335,7 +1198,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_database()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_database_result', $this->input_->isStrictRead());
     else
     {
@@ -378,7 +1241,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->name = $name;
     $args->deleteData = $deleteData;
     $args->cascade = $cascade;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'drop_database', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -394,7 +1257,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_drop_database()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_drop_database_result', $this->input_->isStrictRead());
     else
     {
@@ -435,7 +1298,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_get_databases_args();
     $args->pattern = $pattern;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_databases', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -451,7 +1314,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_databases()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_databases_result', $this->input_->isStrictRead());
     else
     {
@@ -488,7 +1351,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   public function send_get_all_databases()
   {
     $args = new \metastore\ThriftHiveMetastore_get_all_databases_args();
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_all_databases', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -504,7 +1367,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_all_databases()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_all_databases_result', $this->input_->isStrictRead());
     else
     {
@@ -543,7 +1406,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_alter_database_args();
     $args->dbname = $dbname;
     $args->db = $db;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'alter_database', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -559,7 +1422,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_alter_database()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_alter_database_result', $this->input_->isStrictRead());
     else
     {
@@ -597,7 +1460,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_get_type_args();
     $args->name = $name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_type', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -613,7 +1476,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_type()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_type_result', $this->input_->isStrictRead());
     else
     {
@@ -654,7 +1517,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_create_type_args();
     $args->type = $type;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'create_type', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -670,7 +1533,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_create_type()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_create_type_result', $this->input_->isStrictRead());
     else
     {
@@ -714,7 +1577,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_drop_type_args();
     $args->type = $type;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'drop_type', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -730,7 +1593,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_drop_type()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_drop_type_result', $this->input_->isStrictRead());
     else
     {
@@ -771,7 +1634,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_get_type_all_args();
     $args->name = $name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_type_all', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -787,7 +1650,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_type_all()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_type_all_result', $this->input_->isStrictRead());
     else
     {
@@ -826,7 +1689,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_get_fields_args();
     $args->db_name = $db_name;
     $args->table_name = $table_name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_fields', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -842,7 +1705,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_fields()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_fields_result', $this->input_->isStrictRead());
     else
     {
@@ -888,7 +1751,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->db_name = $db_name;
     $args->table_name = $table_name;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_fields_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -904,7 +1767,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_fields_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_fields_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -949,7 +1812,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_get_schema_args();
     $args->db_name = $db_name;
     $args->table_name = $table_name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_schema', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -965,7 +1828,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_schema()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_schema_result', $this->input_->isStrictRead());
     else
     {
@@ -1011,7 +1874,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->db_name = $db_name;
     $args->table_name = $table_name;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_schema_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1027,7 +1890,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_schema_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_schema_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -1071,7 +1934,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_create_table_args();
     $args->tbl = $tbl;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'create_table', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1087,7 +1950,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_create_table()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_create_table_result', $this->input_->isStrictRead());
     else
     {
@@ -1132,7 +1995,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_create_table_with_environment_context_args();
     $args->tbl = $tbl;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'create_table_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1148,7 +2011,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_create_table_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_create_table_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -1194,7 +2057,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->dbname = $dbname;
     $args->name = $name;
     $args->deleteData = $deleteData;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'drop_table', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1210,7 +2073,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_drop_table()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_drop_table_result', $this->input_->isStrictRead());
     else
     {
@@ -1251,7 +2114,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->name = $name;
     $args->deleteData = $deleteData;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'drop_table_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1267,7 +2130,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_drop_table_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_drop_table_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -1306,7 +2169,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_get_tables_args();
     $args->db_name = $db_name;
     $args->pattern = $pattern;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_tables', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1322,7 +2185,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_tables()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_tables_result', $this->input_->isStrictRead());
     else
     {
@@ -1360,7 +2223,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_get_all_tables_args();
     $args->db_name = $db_name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_all_tables', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1376,7 +2239,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_all_tables()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_all_tables_result', $this->input_->isStrictRead());
     else
     {
@@ -1415,7 +2278,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_get_table_args();
     $args->dbname = $dbname;
     $args->tbl_name = $tbl_name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_table', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1431,7 +2294,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_table()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_table_result', $this->input_->isStrictRead());
     else
     {
@@ -1462,18 +2325,18 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("get_table failed: unknown result");
   }
 
-  public function get_table_objects_by_name($dbname, $tbl_names)
+  public function get_table_objects_by_name($dbname, array $tbl_names)
   {
     $this->send_get_table_objects_by_name($dbname, $tbl_names);
     return $this->recv_get_table_objects_by_name();
   }
 
-  public function send_get_table_objects_by_name($dbname, $tbl_names)
+  public function send_get_table_objects_by_name($dbname, array $tbl_names)
   {
     $args = new \metastore\ThriftHiveMetastore_get_table_objects_by_name_args();
     $args->dbname = $dbname;
     $args->tbl_names = $tbl_names;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_table_objects_by_name', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1489,7 +2352,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_table_objects_by_name()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_table_objects_by_name_result', $this->input_->isStrictRead());
     else
     {
@@ -1535,7 +2398,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->dbname = $dbname;
     $args->filter = $filter;
     $args->max_tables = $max_tables;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'get_table_names_by_filter', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1551,7 +2414,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_get_table_names_by_filter()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_get_table_names_by_filter_result', $this->input_->isStrictRead());
     else
     {
@@ -1597,7 +2460,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->dbname = $dbname;
     $args->tbl_name = $tbl_name;
     $args->new_tbl = $new_tbl;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'alter_table', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1613,7 +2476,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_alter_table()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_alter_table_result', $this->input_->isStrictRead());
     else
     {
@@ -1654,7 +2517,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->tbl_name = $tbl_name;
     $args->new_tbl = $new_tbl;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'alter_table_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1670,7 +2533,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_alter_table_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_alter_table_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -1711,7 +2574,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->tbl_name = $tbl_name;
     $args->new_tbl = $new_tbl;
     $args->cascade = $cascade;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'alter_table_with_cascade', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1727,7 +2590,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_alter_table_with_cascade()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_alter_table_with_cascade_result', $this->input_->isStrictRead());
     else
     {
@@ -1765,7 +2628,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_add_partition_args();
     $args->new_part = $new_part;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'add_partition', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1781,7 +2644,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_add_partition()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_add_partition_result', $this->input_->isStrictRead());
     else
     {
@@ -1826,7 +2689,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args = new \metastore\ThriftHiveMetastore_add_partition_with_environment_context_args();
     $args->new_part = $new_part;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'add_partition_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1842,7 +2705,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_add_partition_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_add_partition_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -1876,17 +2739,17 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("add_partition_with_environment_context failed: unknown result");
   }
 
-  public function add_partitions($new_parts)
+  public function add_partitions(array $new_parts)
   {
     $this->send_add_partitions($new_parts);
     return $this->recv_add_partitions();
   }
 
-  public function send_add_partitions($new_parts)
+  public function send_add_partitions(array $new_parts)
   {
     $args = new \metastore\ThriftHiveMetastore_add_partitions_args();
     $args->new_parts = $new_parts;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'add_partitions', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1902,7 +2765,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_add_partitions()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_add_partitions_result', $this->input_->isStrictRead());
     else
     {
@@ -1936,17 +2799,17 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("add_partitions failed: unknown result");
   }
 
-  public function add_partitions_pspec($new_parts)
+  public function add_partitions_pspec(array $new_parts)
   {
     $this->send_add_partitions_pspec($new_parts);
     return $this->recv_add_partitions_pspec();
   }
 
-  public function send_add_partitions_pspec($new_parts)
+  public function send_add_partitions_pspec(array $new_parts)
   {
     $args = new \metastore\ThriftHiveMetastore_add_partitions_pspec_args();
     $args->new_parts = $new_parts;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'add_partitions_pspec', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -1962,7 +2825,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_add_partitions_pspec()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_add_partitions_pspec_result', $this->input_->isStrictRead());
     else
     {
@@ -1996,19 +2859,19 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("add_partitions_pspec failed: unknown result");
   }
 
-  public function append_partition($db_name, $tbl_name, $part_vals)
+  public function append_partition($db_name, $tbl_name, array $part_vals)
   {
     $this->send_append_partition($db_name, $tbl_name, $part_vals);
     return $this->recv_append_partition();
   }
 
-  public function send_append_partition($db_name, $tbl_name, $part_vals)
+  public function send_append_partition($db_name, $tbl_name, array $part_vals)
   {
     $args = new \metastore\ThriftHiveMetastore_append_partition_args();
     $args->db_name = $db_name;
     $args->tbl_name = $tbl_name;
     $args->part_vals = $part_vals;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'append_partition', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2024,7 +2887,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_append_partition()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_append_partition_result', $this->input_->isStrictRead());
     else
     {
@@ -2068,7 +2931,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
   {
     $args = new \metastore\ThriftHiveMetastore_add_partitions_req_args();
     $args->request = $request;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'add_partitions_req', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2084,7 +2947,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_add_partitions_req()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_add_partitions_req_result', $this->input_->isStrictRead());
     else
     {
@@ -2118,20 +2981,20 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("add_partitions_req failed: unknown result");
   }
 
-  public function append_partition_with_environment_context($db_name, $tbl_name, $part_vals, \metastore\EnvironmentContext $environment_context)
+  public function append_partition_with_environment_context($db_name, $tbl_name, array $part_vals, \metastore\EnvironmentContext $environment_context)
   {
     $this->send_append_partition_with_environment_context($db_name, $tbl_name, $part_vals, $environment_context);
     return $this->recv_append_partition_with_environment_context();
   }
 
-  public function send_append_partition_with_environment_context($db_name, $tbl_name, $part_vals, \metastore\EnvironmentContext $environment_context)
+  public function send_append_partition_with_environment_context($db_name, $tbl_name, array $part_vals, \metastore\EnvironmentContext $environment_context)
   {
     $args = new \metastore\ThriftHiveMetastore_append_partition_with_environment_context_args();
     $args->db_name = $db_name;
     $args->tbl_name = $tbl_name;
     $args->part_vals = $part_vals;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'append_partition_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2147,7 +3010,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_append_partition_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_append_partition_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -2193,7 +3056,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->db_name = $db_name;
     $args->tbl_name = $tbl_name;
     $args->part_name = $part_name;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'append_partition_by_name', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2209,7 +3072,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_append_partition_by_name()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_append_partition_by_name_result', $this->input_->isStrictRead());
     else
     {
@@ -2256,7 +3119,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     $args->tbl_name = $tbl_name;
     $args->part_name = $part_name;
     $args->environment_context = $environment_context;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'append_partition_by_name_with_environment_context', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2272,7 +3135,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_append_partition_by_name_with_environment_context()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_append_partition_by_name_with_environment_context_result', $this->input_->isStrictRead());
     else
     {
@@ -2306,20 +3169,20 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("append_partition_by_name_with_environment_context failed: unknown result");
   }
 
-  public function drop_partition($db_name, $tbl_name, $part_vals, $deleteData)
+  public function drop_partition($db_name, $tbl_name, array $part_vals, $deleteData)
   {
     $this->send_drop_partition($db_name, $tbl_name, $part_vals, $deleteData);
     return $this->recv_drop_partition();
   }
 
-  public function send_drop_partition($db_name, $tbl_name, $part_vals, $deleteData)
+  public function send_drop_partition($db_name, $tbl_name, array $part_vals, $deleteData)
   {
     $args = new \metastore\ThriftHiveMetastore_drop_partition_args();
     $args->db_name = $db_name;
     $args->tbl_name = $tbl_name;
     $args->part_vals = $part_vals;
     $args->deleteData = $deleteData;
-    $bin_accel = ($this->output_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_write_binary');
+    $bin_accel = ($this->output_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_write_binary');
     if ($bin_accel)
     {
       thrift_protocol_write_binary($this->output_, 'drop_partition', TMessageType::CALL, $args, $this->seqid_, $this->output_->isStrictWrite());
@@ -2335,7 +3198,7 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
 
   public function recv_drop_partition()
   {
-    $bin_accel = ($this->input_ instanceof TProtocol::$TBINARYPROTOCOLACCELERATED) && function_exists('thrift_protocol_read_binary');
+    $bin_accel = ($this->input_ instanceof TBinaryProtocolAccelerated) && function_exists('thrift_protocol_read_binary');
     if ($bin_accel) $result = thrift_protocol_read_binary($this->input_, '\metastore\ThriftHiveMetastore_drop_partition_result', $this->input_->isStrictRead());
     else
     {
@@ -2366,13 +3229,13 @@ class ThriftHiveMetastoreClient extends \FacebookServiceClient implements \metas
     throw new \Exception("drop_partition failed: unknown result");


<TRUNCATED>

[04/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TMapTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TMapTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TMapTypeEntry.java
index 425603c..3361982 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TMapTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TMapTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TMapTypeEntry implements org.apache.thrift.TBase<TMapTypeEntry, TMapTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TMapTypeEntry implements org.apache.thrift.TBase<TMapTypeEntry, TMapTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TMapTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TMapTypeEntry");
 
   private static final org.apache.thrift.protocol.TField KEY_TYPE_PTR_FIELD_DESC = new org.apache.thrift.protocol.TField("keyTypePtr", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -285,45 +289,45 @@ public class TMapTypeEntry implements org.apache.thrift.TBase<TMapTypeEntry, TMa
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_keyTypePtr = true;
-    builder.append(present_keyTypePtr);
+    list.add(present_keyTypePtr);
     if (present_keyTypePtr)
-      builder.append(keyTypePtr);
+      list.add(keyTypePtr);
 
     boolean present_valueTypePtr = true;
-    builder.append(present_valueTypePtr);
+    list.add(present_valueTypePtr);
     if (present_valueTypePtr)
-      builder.append(valueTypePtr);
+      list.add(valueTypePtr);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TMapTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TMapTypeEntry typedOther = (TMapTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetKeyTypePtr()).compareTo(typedOther.isSetKeyTypePtr());
+    lastComparison = Boolean.valueOf(isSetKeyTypePtr()).compareTo(other.isSetKeyTypePtr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetKeyTypePtr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.keyTypePtr, typedOther.keyTypePtr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.keyTypePtr, other.keyTypePtr);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetValueTypePtr()).compareTo(typedOther.isSetValueTypePtr());
+    lastComparison = Boolean.valueOf(isSetValueTypePtr()).compareTo(other.isSetValueTypePtr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValueTypePtr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.valueTypePtr, typedOther.valueTypePtr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.valueTypePtr, other.valueTypePtr);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionReq.java
index c048161..ff5d48b 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq, TOpenSessionReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq, TOpenSessionReq._Fields>, java.io.Serializable, Cloneable, Comparable<TOpenSessionReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TOpenSessionReq");
 
   private static final org.apache.thrift.protocol.TField CLIENT_PROTOCOL_FIELD_DESC = new org.apache.thrift.protocol.TField("client_protocol", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -122,7 +126,7 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.USERNAME,_Fields.PASSWORD,_Fields.CONFIGURATION};
+  private static final _Fields optionals[] = {_Fields.USERNAME,_Fields.PASSWORD,_Fields.CONFIGURATION};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -166,18 +170,7 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
       this.password = other.password;
     }
     if (other.isSetConfiguration()) {
-      Map<String,String> __this__configuration = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.configuration.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__configuration_copy_key = other_element_key;
-
-        String __this__configuration_copy_value = other_element_value;
-
-        __this__configuration.put(__this__configuration_copy_key, __this__configuration_copy_value);
-      }
+      Map<String,String> __this__configuration = new HashMap<String,String>(other.configuration);
       this.configuration = __this__configuration;
     }
   }
@@ -434,75 +427,75 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_client_protocol = true && (isSetClient_protocol());
-    builder.append(present_client_protocol);
+    list.add(present_client_protocol);
     if (present_client_protocol)
-      builder.append(client_protocol.getValue());
+      list.add(client_protocol.getValue());
 
     boolean present_username = true && (isSetUsername());
-    builder.append(present_username);
+    list.add(present_username);
     if (present_username)
-      builder.append(username);
+      list.add(username);
 
     boolean present_password = true && (isSetPassword());
-    builder.append(present_password);
+    list.add(present_password);
     if (present_password)
-      builder.append(password);
+      list.add(password);
 
     boolean present_configuration = true && (isSetConfiguration());
-    builder.append(present_configuration);
+    list.add(present_configuration);
     if (present_configuration)
-      builder.append(configuration);
+      list.add(configuration);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TOpenSessionReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TOpenSessionReq typedOther = (TOpenSessionReq)other;
 
-    lastComparison = Boolean.valueOf(isSetClient_protocol()).compareTo(typedOther.isSetClient_protocol());
+    lastComparison = Boolean.valueOf(isSetClient_protocol()).compareTo(other.isSetClient_protocol());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetClient_protocol()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.client_protocol, typedOther.client_protocol);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.client_protocol, other.client_protocol);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUsername()).compareTo(typedOther.isSetUsername());
+    lastComparison = Boolean.valueOf(isSetUsername()).compareTo(other.isSetUsername());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUsername()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.username, typedOther.username);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.username, other.username);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPassword()).compareTo(typedOther.isSetPassword());
+    lastComparison = Boolean.valueOf(isSetPassword()).compareTo(other.isSetPassword());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPassword()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.password, typedOther.password);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.password, other.password);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetConfiguration()).compareTo(typedOther.isSetConfiguration());
+    lastComparison = Boolean.valueOf(isSetConfiguration()).compareTo(other.isSetConfiguration());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetConfiguration()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.configuration, typedOther.configuration);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.configuration, other.configuration);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -613,7 +606,7 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
         switch (schemeField.id) {
           case 1: // CLIENT_PROTOCOL
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.client_protocol = TProtocolVersion.findByValue(iprot.readI32());
+              struct.client_protocol = org.apache.hive.service.cli.thrift.TProtocolVersion.findByValue(iprot.readI32());
               struct.setClient_protocolIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -640,13 +633,13 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
               {
                 org.apache.thrift.protocol.TMap _map142 = iprot.readMapBegin();
                 struct.configuration = new HashMap<String,String>(2*_map142.size);
-                for (int _i143 = 0; _i143 < _map142.size; ++_i143)
+                String _key143;
+                String _val144;
+                for (int _i145 = 0; _i145 < _map142.size; ++_i145)
                 {
-                  String _key144; // required
-                  String _val145; // required
-                  _key144 = iprot.readString();
-                  _val145 = iprot.readString();
-                  struct.configuration.put(_key144, _val145);
+                  _key143 = iprot.readString();
+                  _val144 = iprot.readString();
+                  struct.configuration.put(_key143, _val144);
                 }
                 iprot.readMapEnd();
               }
@@ -752,7 +745,7 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
     @Override
     public void read(org.apache.thrift.protocol.TProtocol prot, TOpenSessionReq struct) throws org.apache.thrift.TException {
       TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.client_protocol = TProtocolVersion.findByValue(iprot.readI32());
+      struct.client_protocol = org.apache.hive.service.cli.thrift.TProtocolVersion.findByValue(iprot.readI32());
       struct.setClient_protocolIsSet(true);
       BitSet incoming = iprot.readBitSet(3);
       if (incoming.get(0)) {
@@ -767,13 +760,13 @@ public class TOpenSessionReq implements org.apache.thrift.TBase<TOpenSessionReq,
         {
           org.apache.thrift.protocol.TMap _map148 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.configuration = new HashMap<String,String>(2*_map148.size);
-          for (int _i149 = 0; _i149 < _map148.size; ++_i149)
+          String _key149;
+          String _val150;
+          for (int _i151 = 0; _i151 < _map148.size; ++_i151)
           {
-            String _key150; // required
-            String _val151; // required
-            _key150 = iprot.readString();
-            _val151 = iprot.readString();
-            struct.configuration.put(_key150, _val151);
+            _key149 = iprot.readString();
+            _val150 = iprot.readString();
+            struct.configuration.put(_key149, _val150);
           }
         }
         struct.setConfigurationIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionResp.java
index 351f78b..6753b63 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOpenSessionResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionResp, TOpenSessionResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionResp, TOpenSessionResp._Fields>, java.io.Serializable, Cloneable, Comparable<TOpenSessionResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TOpenSessionResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -122,7 +126,7 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.SESSION_HANDLE,_Fields.CONFIGURATION};
+  private static final _Fields optionals[] = {_Fields.SESSION_HANDLE,_Fields.CONFIGURATION};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -168,18 +172,7 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
       this.sessionHandle = new TSessionHandle(other.sessionHandle);
     }
     if (other.isSetConfiguration()) {
-      Map<String,String> __this__configuration = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.configuration.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__configuration_copy_key = other_element_key;
-
-        String __this__configuration_copy_value = other_element_value;
-
-        __this__configuration.put(__this__configuration_copy_key, __this__configuration_copy_value);
-      }
+      Map<String,String> __this__configuration = new HashMap<String,String>(other.configuration);
       this.configuration = __this__configuration;
     }
   }
@@ -436,75 +429,75 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_serverProtocolVersion = true && (isSetServerProtocolVersion());
-    builder.append(present_serverProtocolVersion);
+    list.add(present_serverProtocolVersion);
     if (present_serverProtocolVersion)
-      builder.append(serverProtocolVersion.getValue());
+      list.add(serverProtocolVersion.getValue());
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_configuration = true && (isSetConfiguration());
-    builder.append(present_configuration);
+    list.add(present_configuration);
     if (present_configuration)
-      builder.append(configuration);
+      list.add(configuration);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TOpenSessionResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TOpenSessionResp typedOther = (TOpenSessionResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetServerProtocolVersion()).compareTo(typedOther.isSetServerProtocolVersion());
+    lastComparison = Boolean.valueOf(isSetServerProtocolVersion()).compareTo(other.isSetServerProtocolVersion());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetServerProtocolVersion()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serverProtocolVersion, typedOther.serverProtocolVersion);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.serverProtocolVersion, other.serverProtocolVersion);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetConfiguration()).compareTo(typedOther.isSetConfiguration());
+    lastComparison = Boolean.valueOf(isSetConfiguration()).compareTo(other.isSetConfiguration());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetConfiguration()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.configuration, typedOther.configuration);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.configuration, other.configuration);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -632,7 +625,7 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
             break;
           case 2: // SERVER_PROTOCOL_VERSION
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.serverProtocolVersion = TProtocolVersion.findByValue(iprot.readI32());
+              struct.serverProtocolVersion = org.apache.hive.service.cli.thrift.TProtocolVersion.findByValue(iprot.readI32());
               struct.setServerProtocolVersionIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -652,13 +645,13 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
               {
                 org.apache.thrift.protocol.TMap _map152 = iprot.readMapBegin();
                 struct.configuration = new HashMap<String,String>(2*_map152.size);
-                for (int _i153 = 0; _i153 < _map152.size; ++_i153)
+                String _key153;
+                String _val154;
+                for (int _i155 = 0; _i155 < _map152.size; ++_i155)
                 {
-                  String _key154; // required
-                  String _val155; // required
-                  _key154 = iprot.readString();
-                  _val155 = iprot.readString();
-                  struct.configuration.put(_key154, _val155);
+                  _key153 = iprot.readString();
+                  _val154 = iprot.readString();
+                  struct.configuration.put(_key153, _val154);
                 }
                 iprot.readMapEnd();
               }
@@ -760,7 +753,7 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
       struct.status = new TStatus();
       struct.status.read(iprot);
       struct.setStatusIsSet(true);
-      struct.serverProtocolVersion = TProtocolVersion.findByValue(iprot.readI32());
+      struct.serverProtocolVersion = org.apache.hive.service.cli.thrift.TProtocolVersion.findByValue(iprot.readI32());
       struct.setServerProtocolVersionIsSet(true);
       BitSet incoming = iprot.readBitSet(2);
       if (incoming.get(0)) {
@@ -772,13 +765,13 @@ public class TOpenSessionResp implements org.apache.thrift.TBase<TOpenSessionRes
         {
           org.apache.thrift.protocol.TMap _map158 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.configuration = new HashMap<String,String>(2*_map158.size);
-          for (int _i159 = 0; _i159 < _map158.size; ++_i159)
+          String _key159;
+          String _val160;
+          for (int _i161 = 0; _i161 < _map158.size; ++_i161)
           {
-            String _key160; // required
-            String _val161; // required
-            _key160 = iprot.readString();
-            _val161 = iprot.readString();
-            struct.configuration.put(_key160, _val161);
+            _key159 = iprot.readString();
+            _val160 = iprot.readString();
+            struct.configuration.put(_key159, _val160);
           }
         }
         struct.setConfigurationIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationHandle.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationHandle.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationHandle.java
index 8fbd875..effc801 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationHandle.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationHandle.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandle, TOperationHandle._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandle, TOperationHandle._Fields>, java.io.Serializable, Cloneable, Comparable<TOperationHandle> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TOperationHandle");
 
   private static final org.apache.thrift.protocol.TField OPERATION_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("operationId", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -125,7 +129,7 @@ public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandl
   private static final int __HASRESULTSET_ISSET_ID = 0;
   private static final int __MODIFIEDROWCOUNT_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.MODIFIED_ROW_COUNT};
+  private static final _Fields optionals[] = {_Fields.MODIFIED_ROW_COUNT};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -411,75 +415,75 @@ public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandl
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_operationId = true && (isSetOperationId());
-    builder.append(present_operationId);
+    list.add(present_operationId);
     if (present_operationId)
-      builder.append(operationId);
+      list.add(operationId);
 
     boolean present_operationType = true && (isSetOperationType());
-    builder.append(present_operationType);
+    list.add(present_operationType);
     if (present_operationType)
-      builder.append(operationType.getValue());
+      list.add(operationType.getValue());
 
     boolean present_hasResultSet = true;
-    builder.append(present_hasResultSet);
+    list.add(present_hasResultSet);
     if (present_hasResultSet)
-      builder.append(hasResultSet);
+      list.add(hasResultSet);
 
     boolean present_modifiedRowCount = true && (isSetModifiedRowCount());
-    builder.append(present_modifiedRowCount);
+    list.add(present_modifiedRowCount);
     if (present_modifiedRowCount)
-      builder.append(modifiedRowCount);
+      list.add(modifiedRowCount);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TOperationHandle other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TOperationHandle typedOther = (TOperationHandle)other;
 
-    lastComparison = Boolean.valueOf(isSetOperationId()).compareTo(typedOther.isSetOperationId());
+    lastComparison = Boolean.valueOf(isSetOperationId()).compareTo(other.isSetOperationId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationId, typedOther.operationId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationId, other.operationId);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationType()).compareTo(typedOther.isSetOperationType());
+    lastComparison = Boolean.valueOf(isSetOperationType()).compareTo(other.isSetOperationType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationType, typedOther.operationType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationType, other.operationType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHasResultSet()).compareTo(typedOther.isSetHasResultSet());
+    lastComparison = Boolean.valueOf(isSetHasResultSet()).compareTo(other.isSetHasResultSet());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHasResultSet()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasResultSet, typedOther.hasResultSet);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasResultSet, other.hasResultSet);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetModifiedRowCount()).compareTo(typedOther.isSetModifiedRowCount());
+    lastComparison = Boolean.valueOf(isSetModifiedRowCount()).compareTo(other.isSetModifiedRowCount());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetModifiedRowCount()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.modifiedRowCount, typedOther.modifiedRowCount);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.modifiedRowCount, other.modifiedRowCount);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -600,7 +604,7 @@ public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandl
             break;
           case 2: // OPERATION_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.operationType = TOperationType.findByValue(iprot.readI32());
+              struct.operationType = org.apache.hive.service.cli.thrift.TOperationType.findByValue(iprot.readI32());
               struct.setOperationTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -689,7 +693,7 @@ public class TOperationHandle implements org.apache.thrift.TBase<TOperationHandl
       struct.operationId = new THandleIdentifier();
       struct.operationId.read(iprot);
       struct.setOperationIdIsSet(true);
-      struct.operationType = TOperationType.findByValue(iprot.readI32());
+      struct.operationType = org.apache.hive.service.cli.thrift.TOperationType.findByValue(iprot.readI32());
       struct.setOperationTypeIsSet(true);
       struct.hasResultSet = iprot.readBool();
       struct.setHasResultSetIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationState.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationState.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationState.java
index 2198662..2dfde1c 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationState.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationState.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationType.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationType.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationType.java
index b6d4b2f..6927740 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationType.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TOperationType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TPrimitiveTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TPrimitiveTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TPrimitiveTypeEntry.java
index 9d2abf2..d40d9ee 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TPrimitiveTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TPrimitiveTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTypeEntry, TPrimitiveTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTypeEntry, TPrimitiveTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TPrimitiveTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TPrimitiveTypeEntry");
 
   private static final org.apache.thrift.protocol.TField TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("type", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -112,7 +116,7 @@ public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTy
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.TYPE_QUALIFIERS};
+  private static final _Fields optionals[] = {_Fields.TYPE_QUALIFIERS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -294,45 +298,45 @@ public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTy
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type.getValue());
+      list.add(type.getValue());
 
     boolean present_typeQualifiers = true && (isSetTypeQualifiers());
-    builder.append(present_typeQualifiers);
+    list.add(present_typeQualifiers);
     if (present_typeQualifiers)
-      builder.append(typeQualifiers);
+      list.add(typeQualifiers);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TPrimitiveTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TPrimitiveTypeEntry typedOther = (TPrimitiveTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTypeQualifiers()).compareTo(typedOther.isSetTypeQualifiers());
+    lastComparison = Boolean.valueOf(isSetTypeQualifiers()).compareTo(other.isSetTypeQualifiers());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTypeQualifiers()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeQualifiers, typedOther.typeQualifiers);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.typeQualifiers, other.typeQualifiers);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -426,7 +430,7 @@ public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTy
         switch (schemeField.id) {
           case 1: // TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.type = TTypeId.findByValue(iprot.readI32());
+              struct.type = org.apache.hive.service.cli.thrift.TTypeId.findByValue(iprot.readI32());
               struct.setTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -497,7 +501,7 @@ public class TPrimitiveTypeEntry implements org.apache.thrift.TBase<TPrimitiveTy
     @Override
     public void read(org.apache.thrift.protocol.TProtocol prot, TPrimitiveTypeEntry struct) throws org.apache.thrift.TException {
       TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.type = TTypeId.findByValue(iprot.readI32());
+      struct.type = org.apache.hive.service.cli.thrift.TTypeId.findByValue(iprot.readI32());
       struct.setTypeIsSet(true);
       BitSet incoming = iprot.readBitSet(1);
       if (incoming.get(0)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TProtocolVersion.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TProtocolVersion.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TProtocolVersion.java
index a4279d2..6e714c6 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TProtocolVersion.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TProtocolVersion.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenReq.java
index a3e39c8..70b1cbe 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TRenewDelegationTokenReq implements org.apache.thrift.TBase<TRenewDelegationTokenReq, TRenewDelegationTokenReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TRenewDelegationTokenReq implements org.apache.thrift.TBase<TRenewDelegationTokenReq, TRenewDelegationTokenReq._Fields>, java.io.Serializable, Cloneable, Comparable<TRenewDelegationTokenReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRenewDelegationTokenReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -283,45 +287,45 @@ public class TRenewDelegationTokenReq implements org.apache.thrift.TBase<TRenewD
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_delegationToken = true && (isSetDelegationToken());
-    builder.append(present_delegationToken);
+    list.add(present_delegationToken);
     if (present_delegationToken)
-      builder.append(delegationToken);
+      list.add(delegationToken);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TRenewDelegationTokenReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TRenewDelegationTokenReq typedOther = (TRenewDelegationTokenReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(typedOther.isSetDelegationToken());
+    lastComparison = Boolean.valueOf(isSetDelegationToken()).compareTo(other.isSetDelegationToken());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDelegationToken()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, typedOther.delegationToken);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.delegationToken, other.delegationToken);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenResp.java
index 5f3eb6c..1bd76c9 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRenewDelegationTokenResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TRenewDelegationTokenResp implements org.apache.thrift.TBase<TRenewDelegationTokenResp, TRenewDelegationTokenResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TRenewDelegationTokenResp implements org.apache.thrift.TBase<TRenewDelegationTokenResp, TRenewDelegationTokenResp._Fields>, java.io.Serializable, Cloneable, Comparable<TRenewDelegationTokenResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRenewDelegationTokenResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TRenewDelegationTokenResp implements org.apache.thrift.TBase<TRenew
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TRenewDelegationTokenResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TRenewDelegationTokenResp typedOther = (TRenewDelegationTokenResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRow.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRow.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRow.java
index a44cfb0..a1ba634 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRow.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRow.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.io.Serializable, Cloneable, Comparable<TRow> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRow");
 
   private static final org.apache.thrift.protocol.TField COL_VALS_FIELD_DESC = new org.apache.thrift.protocol.TField("colVals", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.i
    */
   public TRow(TRow other) {
     if (other.isSetColVals()) {
-      List<TColumnValue> __this__colVals = new ArrayList<TColumnValue>();
+      List<TColumnValue> __this__colVals = new ArrayList<TColumnValue>(other.colVals.size());
       for (TColumnValue other_element : other.colVals) {
         __this__colVals.add(new TColumnValue(other_element));
       }
@@ -245,30 +249,30 @@ public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.i
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_colVals = true && (isSetColVals());
-    builder.append(present_colVals);
+    list.add(present_colVals);
     if (present_colVals)
-      builder.append(colVals);
+      list.add(colVals);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TRow other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TRow typedOther = (TRow)other;
 
-    lastComparison = Boolean.valueOf(isSetColVals()).compareTo(typedOther.isSetColVals());
+    lastComparison = Boolean.valueOf(isSetColVals()).compareTo(other.isSetColVals());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColVals()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colVals, typedOther.colVals);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colVals, other.colVals);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -352,12 +356,12 @@ public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.i
               {
                 org.apache.thrift.protocol.TList _list46 = iprot.readListBegin();
                 struct.colVals = new ArrayList<TColumnValue>(_list46.size);
-                for (int _i47 = 0; _i47 < _list46.size; ++_i47)
+                TColumnValue _elem47;
+                for (int _i48 = 0; _i48 < _list46.size; ++_i48)
                 {
-                  TColumnValue _elem48; // optional
-                  _elem48 = new TColumnValue();
-                  _elem48.read(iprot);
-                  struct.colVals.add(_elem48);
+                  _elem47 = new TColumnValue();
+                  _elem47.read(iprot);
+                  struct.colVals.add(_elem47);
                 }
                 iprot.readListEnd();
               }
@@ -423,12 +427,12 @@ public class TRow implements org.apache.thrift.TBase<TRow, TRow._Fields>, java.i
       {
         org.apache.thrift.protocol.TList _list51 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.colVals = new ArrayList<TColumnValue>(_list51.size);
-        for (int _i52 = 0; _i52 < _list51.size; ++_i52)
+        TColumnValue _elem52;
+        for (int _i53 = 0; _i53 < _list51.size; ++_i53)
         {
-          TColumnValue _elem53; // optional
-          _elem53 = new TColumnValue();
-          _elem53.read(iprot);
-          struct.colVals.add(_elem53);
+          _elem52 = new TColumnValue();
+          _elem52.read(iprot);
+          struct.colVals.add(_elem52);
         }
       }
       struct.setColValsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRowSet.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRowSet.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRowSet.java
index d16c8a4..2124862 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRowSet.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TRowSet.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields>, java.io.Serializable, Cloneable, Comparable<TRowSet> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TRowSet");
 
   private static final org.apache.thrift.protocol.TField START_ROW_OFFSET_FIELD_DESC = new org.apache.thrift.protocol.TField("startRowOffset", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -115,7 +119,7 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
   // isset id assignments
   private static final int __STARTROWOFFSET_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.COLUMNS};
+  private static final _Fields optionals[] = {_Fields.COLUMNS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -151,14 +155,14 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
     __isset_bitfield = other.__isset_bitfield;
     this.startRowOffset = other.startRowOffset;
     if (other.isSetRows()) {
-      List<TRow> __this__rows = new ArrayList<TRow>();
+      List<TRow> __this__rows = new ArrayList<TRow>(other.rows.size());
       for (TRow other_element : other.rows) {
         __this__rows.add(new TRow(other_element));
       }
       this.rows = __this__rows;
     }
     if (other.isSetColumns()) {
-      List<TColumn> __this__columns = new ArrayList<TColumn>();
+      List<TColumn> __this__columns = new ArrayList<TColumn>(other.columns.size());
       for (TColumn other_element : other.columns) {
         __this__columns.add(new TColumn(other_element));
       }
@@ -382,60 +386,60 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_startRowOffset = true;
-    builder.append(present_startRowOffset);
+    list.add(present_startRowOffset);
     if (present_startRowOffset)
-      builder.append(startRowOffset);
+      list.add(startRowOffset);
 
     boolean present_rows = true && (isSetRows());
-    builder.append(present_rows);
+    list.add(present_rows);
     if (present_rows)
-      builder.append(rows);
+      list.add(rows);
 
     boolean present_columns = true && (isSetColumns());
-    builder.append(present_columns);
+    list.add(present_columns);
     if (present_columns)
-      builder.append(columns);
+      list.add(columns);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TRowSet other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TRowSet typedOther = (TRowSet)other;
 
-    lastComparison = Boolean.valueOf(isSetStartRowOffset()).compareTo(typedOther.isSetStartRowOffset());
+    lastComparison = Boolean.valueOf(isSetStartRowOffset()).compareTo(other.isSetStartRowOffset());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStartRowOffset()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRowOffset, typedOther.startRowOffset);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.startRowOffset, other.startRowOffset);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRows()).compareTo(typedOther.isSetRows());
+    lastComparison = Boolean.valueOf(isSetRows()).compareTo(other.isSetRows());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRows()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, typedOther.rows);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rows, other.rows);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColumns()).compareTo(typedOther.isSetColumns());
+    lastComparison = Boolean.valueOf(isSetColumns()).compareTo(other.isSetColumns());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColumns()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, typedOther.columns);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.columns, other.columns);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -547,12 +551,12 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
               {
                 org.apache.thrift.protocol.TList _list118 = iprot.readListBegin();
                 struct.rows = new ArrayList<TRow>(_list118.size);
-                for (int _i119 = 0; _i119 < _list118.size; ++_i119)
+                TRow _elem119;
+                for (int _i120 = 0; _i120 < _list118.size; ++_i120)
                 {
-                  TRow _elem120; // optional
-                  _elem120 = new TRow();
-                  _elem120.read(iprot);
-                  struct.rows.add(_elem120);
+                  _elem119 = new TRow();
+                  _elem119.read(iprot);
+                  struct.rows.add(_elem119);
                 }
                 iprot.readListEnd();
               }
@@ -566,12 +570,12 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
               {
                 org.apache.thrift.protocol.TList _list121 = iprot.readListBegin();
                 struct.columns = new ArrayList<TColumn>(_list121.size);
-                for (int _i122 = 0; _i122 < _list121.size; ++_i122)
+                TColumn _elem122;
+                for (int _i123 = 0; _i123 < _list121.size; ++_i123)
                 {
-                  TColumn _elem123; // optional
-                  _elem123 = new TColumn();
-                  _elem123.read(iprot);
-                  struct.columns.add(_elem123);
+                  _elem122 = new TColumn();
+                  _elem122.read(iprot);
+                  struct.columns.add(_elem122);
                 }
                 iprot.readListEnd();
               }
@@ -671,12 +675,12 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
       {
         org.apache.thrift.protocol.TList _list128 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.rows = new ArrayList<TRow>(_list128.size);
-        for (int _i129 = 0; _i129 < _list128.size; ++_i129)
+        TRow _elem129;
+        for (int _i130 = 0; _i130 < _list128.size; ++_i130)
         {
-          TRow _elem130; // optional
-          _elem130 = new TRow();
-          _elem130.read(iprot);
-          struct.rows.add(_elem130);
+          _elem129 = new TRow();
+          _elem129.read(iprot);
+          struct.rows.add(_elem129);
         }
       }
       struct.setRowsIsSet(true);
@@ -685,12 +689,12 @@ public class TRowSet implements org.apache.thrift.TBase<TRowSet, TRowSet._Fields
         {
           org.apache.thrift.protocol.TList _list131 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.columns = new ArrayList<TColumn>(_list131.size);
-          for (int _i132 = 0; _i132 < _list131.size; ++_i132)
+          TColumn _elem132;
+          for (int _i133 = 0; _i133 < _list131.size; ++_i133)
           {
-            TColumn _elem133; // optional
-            _elem133 = new TColumn();
-            _elem133.read(iprot);
-            struct.columns.add(_elem133);
+            _elem132 = new TColumn();
+            _elem132.read(iprot);
+            struct.columns.add(_elem132);
           }
         }
         struct.setColumnsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TSessionHandle.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TSessionHandle.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TSessionHandle.java
index 82c00dd..2ce1286 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TSessionHandle.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TSessionHandle.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TSessionHandle implements org.apache.thrift.TBase<TSessionHandle, TSessionHandle._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TSessionHandle implements org.apache.thrift.TBase<TSessionHandle, TSessionHandle._Fields>, java.io.Serializable, Cloneable, Comparable<TSessionHandle> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TSessionHandle");
 
   private static final org.apache.thrift.protocol.TField SESSION_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionId", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TSessionHandle implements org.apache.thrift.TBase<TSessionHandle, T
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionId = true && (isSetSessionId());
-    builder.append(present_sessionId);
+    list.add(present_sessionId);
     if (present_sessionId)
-      builder.append(sessionId);
+      list.add(sessionId);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TSessionHandle other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TSessionHandle typedOther = (TSessionHandle)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionId()).compareTo(typedOther.isSetSessionId());
+    lastComparison = Boolean.valueOf(isSetSessionId()).compareTo(other.isSetSessionId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionId, typedOther.sessionId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionId, other.sessionId);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatus.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatus.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatus.java
index 24a746e..0e37511 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatus.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatus.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields>, java.io.Serializable, Cloneable, Comparable<TStatus> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TStatus");
 
   private static final org.apache.thrift.protocol.TField STATUS_CODE_FIELD_DESC = new org.apache.thrift.protocol.TField("statusCode", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -129,7 +133,7 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
   // isset id assignments
   private static final int __ERRORCODE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.INFO_MESSAGES,_Fields.SQL_STATE,_Fields.ERROR_CODE,_Fields.ERROR_MESSAGE};
+  private static final _Fields optionals[] = {_Fields.INFO_MESSAGES,_Fields.SQL_STATE,_Fields.ERROR_CODE,_Fields.ERROR_MESSAGE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -167,10 +171,7 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
       this.statusCode = other.statusCode;
     }
     if (other.isSetInfoMessages()) {
-      List<String> __this__infoMessages = new ArrayList<String>();
-      for (String other_element : other.infoMessages) {
-        __this__infoMessages.add(other_element);
-      }
+      List<String> __this__infoMessages = new ArrayList<String>(other.infoMessages);
       this.infoMessages = __this__infoMessages;
     }
     if (other.isSetSqlState()) {
@@ -483,90 +484,90 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_statusCode = true && (isSetStatusCode());
-    builder.append(present_statusCode);
+    list.add(present_statusCode);
     if (present_statusCode)
-      builder.append(statusCode.getValue());
+      list.add(statusCode.getValue());
 
     boolean present_infoMessages = true && (isSetInfoMessages());
-    builder.append(present_infoMessages);
+    list.add(present_infoMessages);
     if (present_infoMessages)
-      builder.append(infoMessages);
+      list.add(infoMessages);
 
     boolean present_sqlState = true && (isSetSqlState());
-    builder.append(present_sqlState);
+    list.add(present_sqlState);
     if (present_sqlState)
-      builder.append(sqlState);
+      list.add(sqlState);
 
     boolean present_errorCode = true && (isSetErrorCode());
-    builder.append(present_errorCode);
+    list.add(present_errorCode);
     if (present_errorCode)
-      builder.append(errorCode);
+      list.add(errorCode);
 
     boolean present_errorMessage = true && (isSetErrorMessage());
-    builder.append(present_errorMessage);
+    list.add(present_errorMessage);
     if (present_errorMessage)
-      builder.append(errorMessage);
+      list.add(errorMessage);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TStatus other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TStatus typedOther = (TStatus)other;
 
-    lastComparison = Boolean.valueOf(isSetStatusCode()).compareTo(typedOther.isSetStatusCode());
+    lastComparison = Boolean.valueOf(isSetStatusCode()).compareTo(other.isSetStatusCode());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatusCode()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statusCode, typedOther.statusCode);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.statusCode, other.statusCode);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetInfoMessages()).compareTo(typedOther.isSetInfoMessages());
+    lastComparison = Boolean.valueOf(isSetInfoMessages()).compareTo(other.isSetInfoMessages());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetInfoMessages()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoMessages, typedOther.infoMessages);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.infoMessages, other.infoMessages);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSqlState()).compareTo(typedOther.isSetSqlState());
+    lastComparison = Boolean.valueOf(isSetSqlState()).compareTo(other.isSetSqlState());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSqlState()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sqlState, typedOther.sqlState);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sqlState, other.sqlState);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(typedOther.isSetErrorCode());
+    lastComparison = Boolean.valueOf(isSetErrorCode()).compareTo(other.isSetErrorCode());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetErrorCode()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, typedOther.errorCode);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorCode, other.errorCode);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetErrorMessage()).compareTo(typedOther.isSetErrorMessage());
+    lastComparison = Boolean.valueOf(isSetErrorMessage()).compareTo(other.isSetErrorMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetErrorMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorMessage, typedOther.errorMessage);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.errorMessage, other.errorMessage);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -685,7 +686,7 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
         switch (schemeField.id) {
           case 1: // STATUS_CODE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.statusCode = TStatusCode.findByValue(iprot.readI32());
+              struct.statusCode = org.apache.hive.service.cli.thrift.TStatusCode.findByValue(iprot.readI32());
               struct.setStatusCodeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -696,11 +697,11 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
               {
                 org.apache.thrift.protocol.TList _list134 = iprot.readListBegin();
                 struct.infoMessages = new ArrayList<String>(_list134.size);
-                for (int _i135 = 0; _i135 < _list134.size; ++_i135)
+                String _elem135;
+                for (int _i136 = 0; _i136 < _list134.size; ++_i136)
                 {
-                  String _elem136; // optional
-                  _elem136 = iprot.readString();
-                  struct.infoMessages.add(_elem136);
+                  _elem135 = iprot.readString();
+                  struct.infoMessages.add(_elem135);
                 }
                 iprot.readListEnd();
               }
@@ -839,18 +840,18 @@ public class TStatus implements org.apache.thrift.TBase<TStatus, TStatus._Fields
     @Override
     public void read(org.apache.thrift.protocol.TProtocol prot, TStatus struct) throws org.apache.thrift.TException {
       TTupleProtocol iprot = (TTupleProtocol) prot;
-      struct.statusCode = TStatusCode.findByValue(iprot.readI32());
+      struct.statusCode = org.apache.hive.service.cli.thrift.TStatusCode.findByValue(iprot.readI32());
       struct.setStatusCodeIsSet(true);
       BitSet incoming = iprot.readBitSet(4);
       if (incoming.get(0)) {
         {
           org.apache.thrift.protocol.TList _list139 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.infoMessages = new ArrayList<String>(_list139.size);
-          for (int _i140 = 0; _i140 < _list139.size; ++_i140)
+          String _elem140;
+          for (int _i141 = 0; _i141 < _list139.size; ++_i141)
           {
-            String _elem141; // optional
-            _elem141 = iprot.readString();
-            struct.infoMessages.add(_elem141);
+            _elem140 = iprot.readString();
+            struct.infoMessages.add(_elem140);
           }
         }
         struct.setInfoMessagesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatusCode.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatusCode.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatusCode.java
index e7fde45..91d1a97 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatusCode.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TStatusCode.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated


[36/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java
index 525ce0e..1f3e6a8 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionsByExprResult implements org.apache.thrift.TBase<PartitionsByExprResult, PartitionsByExprResult._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionsByExprResult implements org.apache.thrift.TBase<PartitionsByExprResult, PartitionsByExprResult._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionsByExprResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionsByExprResult");
 
   private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -141,7 +145,7 @@ public class PartitionsByExprResult implements org.apache.thrift.TBase<Partition
   public PartitionsByExprResult(PartitionsByExprResult other) {
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetPartitions()) {
-      List<Partition> __this__partitions = new ArrayList<Partition>();
+      List<Partition> __this__partitions = new ArrayList<Partition>(other.partitions.size());
       for (Partition other_element : other.partitions) {
         __this__partitions.add(new Partition(other_element));
       }
@@ -305,45 +309,45 @@ public class PartitionsByExprResult implements org.apache.thrift.TBase<Partition
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partitions = true && (isSetPartitions());
-    builder.append(present_partitions);
+    list.add(present_partitions);
     if (present_partitions)
-      builder.append(partitions);
+      list.add(partitions);
 
     boolean present_hasUnknownPartitions = true;
-    builder.append(present_hasUnknownPartitions);
+    list.add(present_hasUnknownPartitions);
     if (present_hasUnknownPartitions)
-      builder.append(hasUnknownPartitions);
+      list.add(hasUnknownPartitions);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionsByExprResult other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionsByExprResult typedOther = (PartitionsByExprResult)other;
 
-    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(typedOther.isSetPartitions());
+    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, typedOther.partitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHasUnknownPartitions()).compareTo(typedOther.isSetHasUnknownPartitions());
+    lastComparison = Boolean.valueOf(isSetHasUnknownPartitions()).compareTo(other.isSetHasUnknownPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHasUnknownPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasUnknownPartitions, typedOther.hasUnknownPartitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.hasUnknownPartitions, other.hasUnknownPartitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -437,12 +441,12 @@ public class PartitionsByExprResult implements org.apache.thrift.TBase<Partition
               {
                 org.apache.thrift.protocol.TList _list322 = iprot.readListBegin();
                 struct.partitions = new ArrayList<Partition>(_list322.size);
-                for (int _i323 = 0; _i323 < _list322.size; ++_i323)
+                Partition _elem323;
+                for (int _i324 = 0; _i324 < _list322.size; ++_i324)
                 {
-                  Partition _elem324; // optional
-                  _elem324 = new Partition();
-                  _elem324.read(iprot);
-                  struct.partitions.add(_elem324);
+                  _elem323 = new Partition();
+                  _elem323.read(iprot);
+                  struct.partitions.add(_elem323);
                 }
                 iprot.readListEnd();
               }
@@ -520,12 +524,12 @@ public class PartitionsByExprResult implements org.apache.thrift.TBase<Partition
       {
         org.apache.thrift.protocol.TList _list327 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
         struct.partitions = new ArrayList<Partition>(_list327.size);
-        for (int _i328 = 0; _i328 < _list327.size; ++_i328)
+        Partition _elem328;
+        for (int _i329 = 0; _i329 < _list327.size; ++_i329)
         {
-          Partition _elem329; // optional
-          _elem329 = new Partition();
-          _elem329.read(iprot);
-          struct.partitions.add(_elem329);
+          _elem328 = new Partition();
+          _elem328.read(iprot);
+          struct.partitions.add(_elem328);
         }
       }
       struct.setPartitionsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java
index d224453..49bb5ff 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionsStatsRequest implements org.apache.thrift.TBase<PartitionsStatsRequest, PartitionsStatsRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionsStatsRequest implements org.apache.thrift.TBase<PartitionsStatsRequest, PartitionsStatsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionsStatsRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionsStatsRequest");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -162,17 +166,11 @@ public class PartitionsStatsRequest implements org.apache.thrift.TBase<Partition
       this.tblName = other.tblName;
     }
     if (other.isSetColNames()) {
-      List<String> __this__colNames = new ArrayList<String>();
-      for (String other_element : other.colNames) {
-        __this__colNames.add(other_element);
-      }
+      List<String> __this__colNames = new ArrayList<String>(other.colNames);
       this.colNames = __this__colNames;
     }
     if (other.isSetPartNames()) {
-      List<String> __this__partNames = new ArrayList<String>();
-      for (String other_element : other.partNames) {
-        __this__partNames.add(other_element);
-      }
+      List<String> __this__partNames = new ArrayList<String>(other.partNames);
       this.partNames = __this__partNames;
     }
   }
@@ -439,75 +437,75 @@ public class PartitionsStatsRequest implements org.apache.thrift.TBase<Partition
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tblName = true && (isSetTblName());
-    builder.append(present_tblName);
+    list.add(present_tblName);
     if (present_tblName)
-      builder.append(tblName);
+      list.add(tblName);
 
     boolean present_colNames = true && (isSetColNames());
-    builder.append(present_colNames);
+    list.add(present_colNames);
     if (present_colNames)
-      builder.append(colNames);
+      list.add(colNames);
 
     boolean present_partNames = true && (isSetPartNames());
-    builder.append(present_partNames);
+    list.add(present_partNames);
     if (present_partNames)
-      builder.append(partNames);
+      list.add(partNames);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionsStatsRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionsStatsRequest typedOther = (PartitionsStatsRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(typedOther.isSetTblName());
+    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(other.isSetTblName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTblName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, typedOther.tblName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, other.tblName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetColNames()).compareTo(typedOther.isSetColNames());
+    lastComparison = Boolean.valueOf(isSetColNames()).compareTo(other.isSetColNames());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetColNames()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colNames, typedOther.colNames);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.colNames, other.colNames);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartNames()).compareTo(typedOther.isSetPartNames());
+    lastComparison = Boolean.valueOf(isSetPartNames()).compareTo(other.isSetPartNames());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartNames()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partNames, typedOther.partNames);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partNames, other.partNames);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -643,11 +641,11 @@ public class PartitionsStatsRequest implements org.apache.thrift.TBase<Partition
               {
                 org.apache.thrift.protocol.TList _list364 = iprot.readListBegin();
                 struct.colNames = new ArrayList<String>(_list364.size);
-                for (int _i365 = 0; _i365 < _list364.size; ++_i365)
+                String _elem365;
+                for (int _i366 = 0; _i366 < _list364.size; ++_i366)
                 {
-                  String _elem366; // optional
-                  _elem366 = iprot.readString();
-                  struct.colNames.add(_elem366);
+                  _elem365 = iprot.readString();
+                  struct.colNames.add(_elem365);
                 }
                 iprot.readListEnd();
               }
@@ -661,11 +659,11 @@ public class PartitionsStatsRequest implements org.apache.thrift.TBase<Partition
               {
                 org.apache.thrift.protocol.TList _list367 = iprot.readListBegin();
                 struct.partNames = new ArrayList<String>(_list367.size);
-                for (int _i368 = 0; _i368 < _list367.size; ++_i368)
+                String _elem368;
+                for (int _i369 = 0; _i369 < _list367.size; ++_i369)
                 {
-                  String _elem369; // optional
-                  _elem369 = iprot.readString();
-                  struct.partNames.add(_elem369);
+                  _elem368 = iprot.readString();
+                  struct.partNames.add(_elem368);
                 }
                 iprot.readListEnd();
               }
@@ -766,22 +764,22 @@ public class PartitionsStatsRequest implements org.apache.thrift.TBase<Partition
       {
         org.apache.thrift.protocol.TList _list374 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.colNames = new ArrayList<String>(_list374.size);
-        for (int _i375 = 0; _i375 < _list374.size; ++_i375)
+        String _elem375;
+        for (int _i376 = 0; _i376 < _list374.size; ++_i376)
         {
-          String _elem376; // optional
-          _elem376 = iprot.readString();
-          struct.colNames.add(_elem376);
+          _elem375 = iprot.readString();
+          struct.colNames.add(_elem375);
         }
       }
       struct.setColNamesIsSet(true);
       {
         org.apache.thrift.protocol.TList _list377 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.partNames = new ArrayList<String>(_list377.size);
-        for (int _i378 = 0; _i378 < _list377.size; ++_i378)
+        String _elem378;
+        for (int _i379 = 0; _i379 < _list377.size; ++_i379)
         {
-          String _elem379; // optional
-          _elem379 = iprot.readString();
-          struct.partNames.add(_elem379);
+          _elem378 = iprot.readString();
+          struct.partNames.add(_elem378);
         }
       }
       struct.setPartNamesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java
index c9ae14e..217178e 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PartitionsStatsResult implements org.apache.thrift.TBase<PartitionsStatsResult, PartitionsStatsResult._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PartitionsStatsResult implements org.apache.thrift.TBase<PartitionsStatsResult, PartitionsStatsResult._Fields>, java.io.Serializable, Cloneable, Comparable<PartitionsStatsResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PartitionsStatsResult");
 
   private static final org.apache.thrift.protocol.TField PART_STATS_FIELD_DESC = new org.apache.thrift.protocol.TField("partStats", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -130,7 +134,7 @@ public class PartitionsStatsResult implements org.apache.thrift.TBase<Partitions
    */
   public PartitionsStatsResult(PartitionsStatsResult other) {
     if (other.isSetPartStats()) {
-      Map<String,List<ColumnStatisticsObj>> __this__partStats = new HashMap<String,List<ColumnStatisticsObj>>();
+      Map<String,List<ColumnStatisticsObj>> __this__partStats = new HashMap<String,List<ColumnStatisticsObj>>(other.partStats.size());
       for (Map.Entry<String, List<ColumnStatisticsObj>> other_element : other.partStats.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -138,7 +142,7 @@ public class PartitionsStatsResult implements org.apache.thrift.TBase<Partitions
 
         String __this__partStats_copy_key = other_element_key;
 
-        List<ColumnStatisticsObj> __this__partStats_copy_value = new ArrayList<ColumnStatisticsObj>();
+        List<ColumnStatisticsObj> __this__partStats_copy_value = new ArrayList<ColumnStatisticsObj>(other_element_value.size());
         for (ColumnStatisticsObj other_element_value_element : other_element_value) {
           __this__partStats_copy_value.add(new ColumnStatisticsObj(other_element_value_element));
         }
@@ -254,30 +258,30 @@ public class PartitionsStatsResult implements org.apache.thrift.TBase<Partitions
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partStats = true && (isSetPartStats());
-    builder.append(present_partStats);
+    list.add(present_partStats);
     if (present_partStats)
-      builder.append(partStats);
+      list.add(partStats);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PartitionsStatsResult other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PartitionsStatsResult typedOther = (PartitionsStatsResult)other;
 
-    lastComparison = Boolean.valueOf(isSetPartStats()).compareTo(typedOther.isSetPartStats());
+    lastComparison = Boolean.valueOf(isSetPartStats()).compareTo(other.isSetPartStats());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartStats()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partStats, typedOther.partStats);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partStats, other.partStats);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -361,24 +365,24 @@ public class PartitionsStatsResult implements org.apache.thrift.TBase<Partitions
               {
                 org.apache.thrift.protocol.TMap _map338 = iprot.readMapBegin();
                 struct.partStats = new HashMap<String,List<ColumnStatisticsObj>>(2*_map338.size);
-                for (int _i339 = 0; _i339 < _map338.size; ++_i339)
+                String _key339;
+                List<ColumnStatisticsObj> _val340;
+                for (int _i341 = 0; _i341 < _map338.size; ++_i341)
                 {
-                  String _key340; // required
-                  List<ColumnStatisticsObj> _val341; // required
-                  _key340 = iprot.readString();
+                  _key339 = iprot.readString();
                   {
                     org.apache.thrift.protocol.TList _list342 = iprot.readListBegin();
-                    _val341 = new ArrayList<ColumnStatisticsObj>(_list342.size);
-                    for (int _i343 = 0; _i343 < _list342.size; ++_i343)
+                    _val340 = new ArrayList<ColumnStatisticsObj>(_list342.size);
+                    ColumnStatisticsObj _elem343;
+                    for (int _i344 = 0; _i344 < _list342.size; ++_i344)
                     {
-                      ColumnStatisticsObj _elem344; // optional
-                      _elem344 = new ColumnStatisticsObj();
-                      _elem344.read(iprot);
-                      _val341.add(_elem344);
+                      _elem343 = new ColumnStatisticsObj();
+                      _elem343.read(iprot);
+                      _val340.add(_elem343);
                     }
                     iprot.readListEnd();
                   }
-                  struct.partStats.put(_key340, _val341);
+                  struct.partStats.put(_key339, _val340);
                 }
                 iprot.readMapEnd();
               }
@@ -459,23 +463,23 @@ public class PartitionsStatsResult implements org.apache.thrift.TBase<Partitions
       {
         org.apache.thrift.protocol.TMap _map349 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
         struct.partStats = new HashMap<String,List<ColumnStatisticsObj>>(2*_map349.size);
-        for (int _i350 = 0; _i350 < _map349.size; ++_i350)
+        String _key350;
+        List<ColumnStatisticsObj> _val351;
+        for (int _i352 = 0; _i352 < _map349.size; ++_i352)
         {
-          String _key351; // required
-          List<ColumnStatisticsObj> _val352; // required
-          _key351 = iprot.readString();
+          _key350 = iprot.readString();
           {
             org.apache.thrift.protocol.TList _list353 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            _val352 = new ArrayList<ColumnStatisticsObj>(_list353.size);
-            for (int _i354 = 0; _i354 < _list353.size; ++_i354)
+            _val351 = new ArrayList<ColumnStatisticsObj>(_list353.size);
+            ColumnStatisticsObj _elem354;
+            for (int _i355 = 0; _i355 < _list353.size; ++_i355)
             {
-              ColumnStatisticsObj _elem355; // optional
-              _elem355 = new ColumnStatisticsObj();
-              _elem355.read(iprot);
-              _val352.add(_elem355);
+              _elem354 = new ColumnStatisticsObj();
+              _elem354.read(iprot);
+              _val351.add(_elem354);
             }
           }
-          struct.partStats.put(_key351, _val352);
+          struct.partStats.put(_key350, _val351);
         }
       }
       struct.setPartStatsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java
index 0c9518a..1601823 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalPrivilegeSet, PrincipalPrivilegeSet._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalPrivilegeSet, PrincipalPrivilegeSet._Fields>, java.io.Serializable, Cloneable, Comparable<PrincipalPrivilegeSet> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PrincipalPrivilegeSet");
 
   private static final org.apache.thrift.protocol.TField USER_PRIVILEGES_FIELD_DESC = new org.apache.thrift.protocol.TField("userPrivileges", org.apache.thrift.protocol.TType.MAP, (short)1);
@@ -154,7 +158,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
    */
   public PrincipalPrivilegeSet(PrincipalPrivilegeSet other) {
     if (other.isSetUserPrivileges()) {
-      Map<String,List<PrivilegeGrantInfo>> __this__userPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>();
+      Map<String,List<PrivilegeGrantInfo>> __this__userPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(other.userPrivileges.size());
       for (Map.Entry<String, List<PrivilegeGrantInfo>> other_element : other.userPrivileges.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -162,7 +166,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
 
         String __this__userPrivileges_copy_key = other_element_key;
 
-        List<PrivilegeGrantInfo> __this__userPrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>();
+        List<PrivilegeGrantInfo> __this__userPrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>(other_element_value.size());
         for (PrivilegeGrantInfo other_element_value_element : other_element_value) {
           __this__userPrivileges_copy_value.add(new PrivilegeGrantInfo(other_element_value_element));
         }
@@ -172,7 +176,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
       this.userPrivileges = __this__userPrivileges;
     }
     if (other.isSetGroupPrivileges()) {
-      Map<String,List<PrivilegeGrantInfo>> __this__groupPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>();
+      Map<String,List<PrivilegeGrantInfo>> __this__groupPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(other.groupPrivileges.size());
       for (Map.Entry<String, List<PrivilegeGrantInfo>> other_element : other.groupPrivileges.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -180,7 +184,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
 
         String __this__groupPrivileges_copy_key = other_element_key;
 
-        List<PrivilegeGrantInfo> __this__groupPrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>();
+        List<PrivilegeGrantInfo> __this__groupPrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>(other_element_value.size());
         for (PrivilegeGrantInfo other_element_value_element : other_element_value) {
           __this__groupPrivileges_copy_value.add(new PrivilegeGrantInfo(other_element_value_element));
         }
@@ -190,7 +194,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
       this.groupPrivileges = __this__groupPrivileges;
     }
     if (other.isSetRolePrivileges()) {
-      Map<String,List<PrivilegeGrantInfo>> __this__rolePrivileges = new HashMap<String,List<PrivilegeGrantInfo>>();
+      Map<String,List<PrivilegeGrantInfo>> __this__rolePrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(other.rolePrivileges.size());
       for (Map.Entry<String, List<PrivilegeGrantInfo>> other_element : other.rolePrivileges.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -198,7 +202,7 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
 
         String __this__rolePrivileges_copy_key = other_element_key;
 
-        List<PrivilegeGrantInfo> __this__rolePrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>();
+        List<PrivilegeGrantInfo> __this__rolePrivileges_copy_value = new ArrayList<PrivilegeGrantInfo>(other_element_value.size());
         for (PrivilegeGrantInfo other_element_value_element : other_element_value) {
           __this__rolePrivileges_copy_value.add(new PrivilegeGrantInfo(other_element_value_element));
         }
@@ -428,60 +432,60 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_userPrivileges = true && (isSetUserPrivileges());
-    builder.append(present_userPrivileges);
+    list.add(present_userPrivileges);
     if (present_userPrivileges)
-      builder.append(userPrivileges);
+      list.add(userPrivileges);
 
     boolean present_groupPrivileges = true && (isSetGroupPrivileges());
-    builder.append(present_groupPrivileges);
+    list.add(present_groupPrivileges);
     if (present_groupPrivileges)
-      builder.append(groupPrivileges);
+      list.add(groupPrivileges);
 
     boolean present_rolePrivileges = true && (isSetRolePrivileges());
-    builder.append(present_rolePrivileges);
+    list.add(present_rolePrivileges);
     if (present_rolePrivileges)
-      builder.append(rolePrivileges);
+      list.add(rolePrivileges);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PrincipalPrivilegeSet other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PrincipalPrivilegeSet typedOther = (PrincipalPrivilegeSet)other;
 
-    lastComparison = Boolean.valueOf(isSetUserPrivileges()).compareTo(typedOther.isSetUserPrivileges());
+    lastComparison = Boolean.valueOf(isSetUserPrivileges()).compareTo(other.isSetUserPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUserPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.userPrivileges, typedOther.userPrivileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.userPrivileges, other.userPrivileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGroupPrivileges()).compareTo(typedOther.isSetGroupPrivileges());
+    lastComparison = Boolean.valueOf(isSetGroupPrivileges()).compareTo(other.isSetGroupPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGroupPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.groupPrivileges, typedOther.groupPrivileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.groupPrivileges, other.groupPrivileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRolePrivileges()).compareTo(typedOther.isSetRolePrivileges());
+    lastComparison = Boolean.valueOf(isSetRolePrivileges()).compareTo(other.isSetRolePrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRolePrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rolePrivileges, typedOther.rolePrivileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.rolePrivileges, other.rolePrivileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -577,24 +581,24 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
               {
                 org.apache.thrift.protocol.TMap _map24 = iprot.readMapBegin();
                 struct.userPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map24.size);
-                for (int _i25 = 0; _i25 < _map24.size; ++_i25)
+                String _key25;
+                List<PrivilegeGrantInfo> _val26;
+                for (int _i27 = 0; _i27 < _map24.size; ++_i27)
                 {
-                  String _key26; // required
-                  List<PrivilegeGrantInfo> _val27; // required
-                  _key26 = iprot.readString();
+                  _key25 = iprot.readString();
                   {
                     org.apache.thrift.protocol.TList _list28 = iprot.readListBegin();
-                    _val27 = new ArrayList<PrivilegeGrantInfo>(_list28.size);
-                    for (int _i29 = 0; _i29 < _list28.size; ++_i29)
+                    _val26 = new ArrayList<PrivilegeGrantInfo>(_list28.size);
+                    PrivilegeGrantInfo _elem29;
+                    for (int _i30 = 0; _i30 < _list28.size; ++_i30)
                     {
-                      PrivilegeGrantInfo _elem30; // optional
-                      _elem30 = new PrivilegeGrantInfo();
-                      _elem30.read(iprot);
-                      _val27.add(_elem30);
+                      _elem29 = new PrivilegeGrantInfo();
+                      _elem29.read(iprot);
+                      _val26.add(_elem29);
                     }
                     iprot.readListEnd();
                   }
-                  struct.userPrivileges.put(_key26, _val27);
+                  struct.userPrivileges.put(_key25, _val26);
                 }
                 iprot.readMapEnd();
               }
@@ -608,24 +612,24 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
               {
                 org.apache.thrift.protocol.TMap _map31 = iprot.readMapBegin();
                 struct.groupPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map31.size);
-                for (int _i32 = 0; _i32 < _map31.size; ++_i32)
+                String _key32;
+                List<PrivilegeGrantInfo> _val33;
+                for (int _i34 = 0; _i34 < _map31.size; ++_i34)
                 {
-                  String _key33; // required
-                  List<PrivilegeGrantInfo> _val34; // required
-                  _key33 = iprot.readString();
+                  _key32 = iprot.readString();
                   {
                     org.apache.thrift.protocol.TList _list35 = iprot.readListBegin();
-                    _val34 = new ArrayList<PrivilegeGrantInfo>(_list35.size);
-                    for (int _i36 = 0; _i36 < _list35.size; ++_i36)
+                    _val33 = new ArrayList<PrivilegeGrantInfo>(_list35.size);
+                    PrivilegeGrantInfo _elem36;
+                    for (int _i37 = 0; _i37 < _list35.size; ++_i37)
                     {
-                      PrivilegeGrantInfo _elem37; // optional
-                      _elem37 = new PrivilegeGrantInfo();
-                      _elem37.read(iprot);
-                      _val34.add(_elem37);
+                      _elem36 = new PrivilegeGrantInfo();
+                      _elem36.read(iprot);
+                      _val33.add(_elem36);
                     }
                     iprot.readListEnd();
                   }
-                  struct.groupPrivileges.put(_key33, _val34);
+                  struct.groupPrivileges.put(_key32, _val33);
                 }
                 iprot.readMapEnd();
               }
@@ -639,24 +643,24 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
               {
                 org.apache.thrift.protocol.TMap _map38 = iprot.readMapBegin();
                 struct.rolePrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map38.size);
-                for (int _i39 = 0; _i39 < _map38.size; ++_i39)
+                String _key39;
+                List<PrivilegeGrantInfo> _val40;
+                for (int _i41 = 0; _i41 < _map38.size; ++_i41)
                 {
-                  String _key40; // required
-                  List<PrivilegeGrantInfo> _val41; // required
-                  _key40 = iprot.readString();
+                  _key39 = iprot.readString();
                   {
                     org.apache.thrift.protocol.TList _list42 = iprot.readListBegin();
-                    _val41 = new ArrayList<PrivilegeGrantInfo>(_list42.size);
-                    for (int _i43 = 0; _i43 < _list42.size; ++_i43)
+                    _val40 = new ArrayList<PrivilegeGrantInfo>(_list42.size);
+                    PrivilegeGrantInfo _elem43;
+                    for (int _i44 = 0; _i44 < _list42.size; ++_i44)
                     {
-                      PrivilegeGrantInfo _elem44; // optional
-                      _elem44 = new PrivilegeGrantInfo();
-                      _elem44.read(iprot);
-                      _val41.add(_elem44);
+                      _elem43 = new PrivilegeGrantInfo();
+                      _elem43.read(iprot);
+                      _val40.add(_elem43);
                     }
                     iprot.readListEnd();
                   }
-                  struct.rolePrivileges.put(_key40, _val41);
+                  struct.rolePrivileges.put(_key39, _val40);
                 }
                 iprot.readMapEnd();
               }
@@ -824,23 +828,23 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
         {
           org.apache.thrift.protocol.TMap _map57 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.userPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map57.size);
-          for (int _i58 = 0; _i58 < _map57.size; ++_i58)
+          String _key58;
+          List<PrivilegeGrantInfo> _val59;
+          for (int _i60 = 0; _i60 < _map57.size; ++_i60)
           {
-            String _key59; // required
-            List<PrivilegeGrantInfo> _val60; // required
-            _key59 = iprot.readString();
+            _key58 = iprot.readString();
             {
               org.apache.thrift.protocol.TList _list61 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-              _val60 = new ArrayList<PrivilegeGrantInfo>(_list61.size);
-              for (int _i62 = 0; _i62 < _list61.size; ++_i62)
+              _val59 = new ArrayList<PrivilegeGrantInfo>(_list61.size);
+              PrivilegeGrantInfo _elem62;
+              for (int _i63 = 0; _i63 < _list61.size; ++_i63)
               {
-                PrivilegeGrantInfo _elem63; // optional
-                _elem63 = new PrivilegeGrantInfo();
-                _elem63.read(iprot);
-                _val60.add(_elem63);
+                _elem62 = new PrivilegeGrantInfo();
+                _elem62.read(iprot);
+                _val59.add(_elem62);
               }
             }
-            struct.userPrivileges.put(_key59, _val60);
+            struct.userPrivileges.put(_key58, _val59);
           }
         }
         struct.setUserPrivilegesIsSet(true);
@@ -849,23 +853,23 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
         {
           org.apache.thrift.protocol.TMap _map64 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.groupPrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map64.size);
-          for (int _i65 = 0; _i65 < _map64.size; ++_i65)
+          String _key65;
+          List<PrivilegeGrantInfo> _val66;
+          for (int _i67 = 0; _i67 < _map64.size; ++_i67)
           {
-            String _key66; // required
-            List<PrivilegeGrantInfo> _val67; // required
-            _key66 = iprot.readString();
+            _key65 = iprot.readString();
             {
               org.apache.thrift.protocol.TList _list68 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-              _val67 = new ArrayList<PrivilegeGrantInfo>(_list68.size);
-              for (int _i69 = 0; _i69 < _list68.size; ++_i69)
+              _val66 = new ArrayList<PrivilegeGrantInfo>(_list68.size);
+              PrivilegeGrantInfo _elem69;
+              for (int _i70 = 0; _i70 < _list68.size; ++_i70)
               {
-                PrivilegeGrantInfo _elem70; // optional
-                _elem70 = new PrivilegeGrantInfo();
-                _elem70.read(iprot);
-                _val67.add(_elem70);
+                _elem69 = new PrivilegeGrantInfo();
+                _elem69.read(iprot);
+                _val66.add(_elem69);
               }
             }
-            struct.groupPrivileges.put(_key66, _val67);
+            struct.groupPrivileges.put(_key65, _val66);
           }
         }
         struct.setGroupPrivilegesIsSet(true);
@@ -874,23 +878,23 @@ public class PrincipalPrivilegeSet implements org.apache.thrift.TBase<PrincipalP
         {
           org.apache.thrift.protocol.TMap _map71 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.rolePrivileges = new HashMap<String,List<PrivilegeGrantInfo>>(2*_map71.size);
-          for (int _i72 = 0; _i72 < _map71.size; ++_i72)
+          String _key72;
+          List<PrivilegeGrantInfo> _val73;
+          for (int _i74 = 0; _i74 < _map71.size; ++_i74)
           {
-            String _key73; // required
-            List<PrivilegeGrantInfo> _val74; // required
-            _key73 = iprot.readString();
+            _key72 = iprot.readString();
             {
               org.apache.thrift.protocol.TList _list75 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-              _val74 = new ArrayList<PrivilegeGrantInfo>(_list75.size);
-              for (int _i76 = 0; _i76 < _list75.size; ++_i76)
+              _val73 = new ArrayList<PrivilegeGrantInfo>(_list75.size);
+              PrivilegeGrantInfo _elem76;
+              for (int _i77 = 0; _i77 < _list75.size; ++_i77)
               {
-                PrivilegeGrantInfo _elem77; // optional
-                _elem77 = new PrivilegeGrantInfo();
-                _elem77.read(iprot);
-                _val74.add(_elem77);
+                _elem76 = new PrivilegeGrantInfo();
+                _elem76.read(iprot);
+                _val73.add(_elem76);
               }
             }
-            struct.rolePrivileges.put(_key73, _val74);
+            struct.rolePrivileges.put(_key72, _val73);
           }
         }
         struct.setRolePrivilegesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalType.java
index d405d4a..65e937e 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java
index 4285ed8..dead805 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, PrivilegeBag._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, PrivilegeBag._Fields>, java.io.Serializable, Cloneable, Comparable<PrivilegeBag> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PrivilegeBag");
 
   private static final org.apache.thrift.protocol.TField PRIVILEGES_FIELD_DESC = new org.apache.thrift.protocol.TField("privileges", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -128,7 +132,7 @@ public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, Privi
    */
   public PrivilegeBag(PrivilegeBag other) {
     if (other.isSetPrivileges()) {
-      List<HiveObjectPrivilege> __this__privileges = new ArrayList<HiveObjectPrivilege>();
+      List<HiveObjectPrivilege> __this__privileges = new ArrayList<HiveObjectPrivilege>(other.privileges.size());
       for (HiveObjectPrivilege other_element : other.privileges) {
         __this__privileges.add(new HiveObjectPrivilege(other_element));
       }
@@ -245,30 +249,30 @@ public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, Privi
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PrivilegeBag other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PrivilegeBag typedOther = (PrivilegeBag)other;
 
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -348,12 +352,12 @@ public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, Privi
               {
                 org.apache.thrift.protocol.TList _list16 = iprot.readListBegin();
                 struct.privileges = new ArrayList<HiveObjectPrivilege>(_list16.size);
-                for (int _i17 = 0; _i17 < _list16.size; ++_i17)
+                HiveObjectPrivilege _elem17;
+                for (int _i18 = 0; _i18 < _list16.size; ++_i18)
                 {
-                  HiveObjectPrivilege _elem18; // optional
-                  _elem18 = new HiveObjectPrivilege();
-                  _elem18.read(iprot);
-                  struct.privileges.add(_elem18);
+                  _elem17 = new HiveObjectPrivilege();
+                  _elem17.read(iprot);
+                  struct.privileges.add(_elem17);
                 }
                 iprot.readListEnd();
               }
@@ -428,12 +432,12 @@ public class PrivilegeBag implements org.apache.thrift.TBase<PrivilegeBag, Privi
         {
           org.apache.thrift.protocol.TList _list21 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.privileges = new ArrayList<HiveObjectPrivilege>(_list21.size);
-          for (int _i22 = 0; _i22 < _list21.size; ++_i22)
+          HiveObjectPrivilege _elem22;
+          for (int _i23 = 0; _i23 < _list21.size; ++_i23)
           {
-            HiveObjectPrivilege _elem23; // optional
-            _elem23 = new HiveObjectPrivilege();
-            _elem23.read(iprot);
-            struct.privileges.add(_elem23);
+            _elem22 = new HiveObjectPrivilege();
+            _elem22.read(iprot);
+            struct.privileges.add(_elem22);
           }
         }
         struct.setPrivilegesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeGrantInfo.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeGrantInfo.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeGrantInfo.java
index 5869457..1ebe09b 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeGrantInfo.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeGrantInfo.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class PrivilegeGrantInfo implements org.apache.thrift.TBase<PrivilegeGrantInfo, PrivilegeGrantInfo._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class PrivilegeGrantInfo implements org.apache.thrift.TBase<PrivilegeGrantInfo, PrivilegeGrantInfo._Fields>, java.io.Serializable, Cloneable, Comparable<PrivilegeGrantInfo> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("PrivilegeGrantInfo");
 
   private static final org.apache.thrift.protocol.TField PRIVILEGE_FIELD_DESC = new org.apache.thrift.protocol.TField("privilege", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -471,90 +475,90 @@ public class PrivilegeGrantInfo implements org.apache.thrift.TBase<PrivilegeGran
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_privilege = true && (isSetPrivilege());
-    builder.append(present_privilege);
+    list.add(present_privilege);
     if (present_privilege)
-      builder.append(privilege);
+      list.add(privilege);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_grantor = true && (isSetGrantor());
-    builder.append(present_grantor);
+    list.add(present_grantor);
     if (present_grantor)
-      builder.append(grantor);
+      list.add(grantor);
 
     boolean present_grantorType = true && (isSetGrantorType());
-    builder.append(present_grantorType);
+    list.add(present_grantorType);
     if (present_grantorType)
-      builder.append(grantorType.getValue());
+      list.add(grantorType.getValue());
 
     boolean present_grantOption = true;
-    builder.append(present_grantOption);
+    list.add(present_grantOption);
     if (present_grantOption)
-      builder.append(grantOption);
+      list.add(grantOption);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(PrivilegeGrantInfo other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    PrivilegeGrantInfo typedOther = (PrivilegeGrantInfo)other;
 
-    lastComparison = Boolean.valueOf(isSetPrivilege()).compareTo(typedOther.isSetPrivilege());
+    lastComparison = Boolean.valueOf(isSetPrivilege()).compareTo(other.isSetPrivilege());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivilege()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privilege, typedOther.privilege);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privilege, other.privilege);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantor()).compareTo(typedOther.isSetGrantor());
+    lastComparison = Boolean.valueOf(isSetGrantor()).compareTo(other.isSetGrantor());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantor()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantor, typedOther.grantor);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantor, other.grantor);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantorType()).compareTo(typedOther.isSetGrantorType());
+    lastComparison = Boolean.valueOf(isSetGrantorType()).compareTo(other.isSetGrantorType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantorType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorType, typedOther.grantorType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantorType, other.grantorType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(typedOther.isSetGrantOption());
+    lastComparison = Boolean.valueOf(isSetGrantOption()).compareTo(other.isSetGrantOption());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGrantOption()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, typedOther.grantOption);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.grantOption, other.grantOption);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -681,7 +685,7 @@ public class PrivilegeGrantInfo implements org.apache.thrift.TBase<PrivilegeGran
             break;
           case 4: // GRANTOR_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.grantorType = PrincipalType.findByValue(iprot.readI32());
+              struct.grantorType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setGrantorTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -797,7 +801,7 @@ public class PrivilegeGrantInfo implements org.apache.thrift.TBase<PrivilegeGran
         struct.setGrantorIsSet(true);
       }
       if (incoming.get(3)) {
-        struct.grantorType = PrincipalType.findByValue(iprot.readI32());
+        struct.grantorType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setGrantorTypeIsSet(true);
       }
       if (incoming.get(4)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RequestPartsSpec.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RequestPartsSpec.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RequestPartsSpec.java
index c2bb231..9207934 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RequestPartsSpec.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/RequestPartsSpec.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,11 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec, RequestPartsSpec._Fields> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("RequestPartsSpec");
   private static final org.apache.thrift.protocol.TField NAMES_FIELD_DESC = new org.apache.thrift.protocol.TField("names", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -167,11 +170,11 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
             {
               org.apache.thrift.protocol.TList _list404 = iprot.readListBegin();
               names = new ArrayList<String>(_list404.size);
-              for (int _i405 = 0; _i405 < _list404.size; ++_i405)
+              String _elem405;
+              for (int _i406 = 0; _i406 < _list404.size; ++_i406)
               {
-                String _elem406; // optional
-                _elem406 = iprot.readString();
-                names.add(_elem406);
+                _elem405 = iprot.readString();
+                names.add(_elem405);
               }
               iprot.readListEnd();
             }
@@ -186,12 +189,12 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
             {
               org.apache.thrift.protocol.TList _list407 = iprot.readListBegin();
               exprs = new ArrayList<DropPartitionsExpr>(_list407.size);
-              for (int _i408 = 0; _i408 < _list407.size; ++_i408)
+              DropPartitionsExpr _elem408;
+              for (int _i409 = 0; _i409 < _list407.size; ++_i409)
               {
-                DropPartitionsExpr _elem409; // optional
-                _elem409 = new DropPartitionsExpr();
-                _elem409.read(iprot);
-                exprs.add(_elem409);
+                _elem408 = new DropPartitionsExpr();
+                _elem408.read(iprot);
+                exprs.add(_elem408);
               }
               iprot.readListEnd();
             }
@@ -204,6 +207,7 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
           throw new IllegalStateException("setField wasn't null, but didn't match any of the case statements!");
       }
     } else {
+      org.apache.thrift.protocol.TProtocolUtil.skip(iprot, field.type);
       return null;
     }
   }
@@ -248,11 +252,11 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
           {
             org.apache.thrift.protocol.TList _list412 = iprot.readListBegin();
             names = new ArrayList<String>(_list412.size);
-            for (int _i413 = 0; _i413 < _list412.size; ++_i413)
+            String _elem413;
+            for (int _i414 = 0; _i414 < _list412.size; ++_i414)
             {
-              String _elem414; // optional
-              _elem414 = iprot.readString();
-              names.add(_elem414);
+              _elem413 = iprot.readString();
+              names.add(_elem413);
             }
             iprot.readListEnd();
           }
@@ -262,12 +266,12 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
           {
             org.apache.thrift.protocol.TList _list415 = iprot.readListBegin();
             exprs = new ArrayList<DropPartitionsExpr>(_list415.size);
-            for (int _i416 = 0; _i416 < _list415.size; ++_i416)
+            DropPartitionsExpr _elem416;
+            for (int _i417 = 0; _i417 < _list415.size; ++_i417)
             {
-              DropPartitionsExpr _elem417; // optional
-              _elem417 = new DropPartitionsExpr();
-              _elem417.read(iprot);
-              exprs.add(_elem417);
+              _elem416 = new DropPartitionsExpr();
+              _elem416.read(iprot);
+              exprs.add(_elem416);
             }
             iprot.readListEnd();
           }
@@ -399,19 +403,19 @@ public class RequestPartsSpec extends org.apache.thrift.TUnion<RequestPartsSpec,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder hcb = new HashCodeBuilder();
-    hcb.append(this.getClass().getName());
+    List<Object> list = new ArrayList<Object>();
+    list.add(this.getClass().getName());
     org.apache.thrift.TFieldIdEnum setField = getSetField();
     if (setField != null) {
-      hcb.append(setField.getThriftFieldId());
+      list.add(setField.getThriftFieldId());
       Object value = getFieldValue();
       if (value instanceof org.apache.thrift.TEnum) {
-        hcb.append(((org.apache.thrift.TEnum)getFieldValue()).getValue());
+        list.add(((org.apache.thrift.TEnum)getFieldValue()).getValue());
       } else {
-        hcb.append(value);
+        list.add(value);
       }
     }
-    return hcb.toHashCode();
+    return list.hashCode();
   }
   private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
     try {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceType.java
index b8cb4f1..861a6db 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceUri.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceUri.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceUri.java
index c230eab..5aa4c51 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceUri.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ResourceUri.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ResourceUri implements org.apache.thrift.TBase<ResourceUri, ResourceUri._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ResourceUri implements org.apache.thrift.TBase<ResourceUri, ResourceUri._Fields>, java.io.Serializable, Cloneable, Comparable<ResourceUri> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ResourceUri");
 
   private static final org.apache.thrift.protocol.TField RESOURCE_TYPE_FIELD_DESC = new org.apache.thrift.protocol.TField("resourceType", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -295,45 +299,45 @@ public class ResourceUri implements org.apache.thrift.TBase<ResourceUri, Resourc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_resourceType = true && (isSetResourceType());
-    builder.append(present_resourceType);
+    list.add(present_resourceType);
     if (present_resourceType)
-      builder.append(resourceType.getValue());
+      list.add(resourceType.getValue());
 
     boolean present_uri = true && (isSetUri());
-    builder.append(present_uri);
+    list.add(present_uri);
     if (present_uri)
-      builder.append(uri);
+      list.add(uri);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ResourceUri other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ResourceUri typedOther = (ResourceUri)other;
 
-    lastComparison = Boolean.valueOf(isSetResourceType()).compareTo(typedOther.isSetResourceType());
+    lastComparison = Boolean.valueOf(isSetResourceType()).compareTo(other.isSetResourceType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetResourceType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.resourceType, typedOther.resourceType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.resourceType, other.resourceType);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUri()).compareTo(typedOther.isSetUri());
+    lastComparison = Boolean.valueOf(isSetUri()).compareTo(other.isSetUri());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUri()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.uri, typedOther.uri);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.uri, other.uri);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -418,7 +422,7 @@ public class ResourceUri implements org.apache.thrift.TBase<ResourceUri, Resourc
         switch (schemeField.id) {
           case 1: // RESOURCE_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.resourceType = ResourceType.findByValue(iprot.readI32());
+              struct.resourceType = org.apache.hadoop.hive.metastore.api.ResourceType.findByValue(iprot.readI32());
               struct.setResourceTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -493,7 +497,7 @@ public class ResourceUri implements org.apache.thrift.TBase<ResourceUri, Resourc
       TTupleProtocol iprot = (TTupleProtocol) prot;
       BitSet incoming = iprot.readBitSet(2);
       if (incoming.get(0)) {
-        struct.resourceType = ResourceType.findByValue(iprot.readI32());
+        struct.resourceType = org.apache.hadoop.hive.metastore.api.ResourceType.findByValue(iprot.readI32());
         struct.setResourceTypeIsSet(true);
       }
       if (incoming.get(1)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Role.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Role.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Role.java
index 35fcf58..c1bb4cb 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Role.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Role.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Role implements org.apache.thrift.TBase<Role, Role._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Role implements org.apache.thrift.TBase<Role, Role._Fields>, java.io.Serializable, Cloneable, Comparable<Role> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Role");
 
   private static final org.apache.thrift.protocol.TField ROLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("roleName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -343,60 +347,60 @@ public class Role implements org.apache.thrift.TBase<Role, Role._Fields>, java.i
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_roleName = true && (isSetRoleName());
-    builder.append(present_roleName);
+    list.add(present_roleName);
     if (present_roleName)
-      builder.append(roleName);
+      list.add(roleName);
 
     boolean present_createTime = true;
-    builder.append(present_createTime);
+    list.add(present_createTime);
     if (present_createTime)
-      builder.append(createTime);
+      list.add(createTime);
 
     boolean present_ownerName = true && (isSetOwnerName());
-    builder.append(present_ownerName);
+    list.add(present_ownerName);
     if (present_ownerName)
-      builder.append(ownerName);
+      list.add(ownerName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Role other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Role typedOther = (Role)other;
 
-    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(typedOther.isSetRoleName());
+    lastComparison = Boolean.valueOf(isSetRoleName()).compareTo(other.isSetRoleName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRoleName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, typedOther.roleName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.roleName, other.roleName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(typedOther.isSetCreateTime());
+    lastComparison = Boolean.valueOf(isSetCreateTime()).compareTo(other.isSetCreateTime());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCreateTime()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, typedOther.createTime);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.createTime, other.createTime);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(typedOther.isSetOwnerName());
+    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(other.isSetOwnerName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwnerName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, typedOther.ownerName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, other.ownerName);
       if (lastComparison != 0) {
         return lastComparison;
       }


[17/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/Complex.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/Complex.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/Complex.java
index ff0c1f2..9cda2a7 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/Complex.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/Complex.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields>, java.io.Serializable, Cloneable, Comparable<Complex> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Complex");
 
   private static final org.apache.thrift.protocol.TField AINT_FIELD_DESC = new org.apache.thrift.protocol.TField("aint", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -227,43 +231,26 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
       this.aString = other.aString;
     }
     if (other.isSetLint()) {
-      List<Integer> __this__lint = new ArrayList<Integer>();
-      for (Integer other_element : other.lint) {
-        __this__lint.add(other_element);
-      }
+      List<Integer> __this__lint = new ArrayList<Integer>(other.lint);
       this.lint = __this__lint;
     }
     if (other.isSetLString()) {
-      List<String> __this__lString = new ArrayList<String>();
-      for (String other_element : other.lString) {
-        __this__lString.add(other_element);
-      }
+      List<String> __this__lString = new ArrayList<String>(other.lString);
       this.lString = __this__lString;
     }
     if (other.isSetLintString()) {
-      List<IntString> __this__lintString = new ArrayList<IntString>();
+      List<IntString> __this__lintString = new ArrayList<IntString>(other.lintString.size());
       for (IntString other_element : other.lintString) {
         __this__lintString.add(new IntString(other_element));
       }
       this.lintString = __this__lintString;
     }
     if (other.isSetMStringString()) {
-      Map<String,String> __this__mStringString = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.mStringString.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__mStringString_copy_key = other_element_key;
-
-        String __this__mStringString_copy_value = other_element_value;
-
-        __this__mStringString.put(__this__mStringString_copy_key, __this__mStringString_copy_value);
-      }
+      Map<String,String> __this__mStringString = new HashMap<String,String>(other.mStringString);
       this.mStringString = __this__mStringString;
     }
     if (other.isSetAttributes()) {
-      Map<String,Map<String,Map<String,PropValueUnion>>> __this__attributes = new HashMap<String,Map<String,Map<String,PropValueUnion>>>();
+      Map<String,Map<String,Map<String,PropValueUnion>>> __this__attributes = new HashMap<String,Map<String,Map<String,PropValueUnion>>>(other.attributes.size());
       for (Map.Entry<String, Map<String,Map<String,PropValueUnion>>> other_element : other.attributes.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -271,7 +258,7 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
 
         String __this__attributes_copy_key = other_element_key;
 
-        Map<String,Map<String,PropValueUnion>> __this__attributes_copy_value = new HashMap<String,Map<String,PropValueUnion>>();
+        Map<String,Map<String,PropValueUnion>> __this__attributes_copy_value = new HashMap<String,Map<String,PropValueUnion>>(other_element_value.size());
         for (Map.Entry<String, Map<String,PropValueUnion>> other_element_value_element : other_element_value.entrySet()) {
 
           String other_element_value_element_key = other_element_value_element.getKey();
@@ -279,7 +266,7 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
 
           String __this__attributes_copy_value_copy_key = other_element_value_element_key;
 
-          Map<String,PropValueUnion> __this__attributes_copy_value_copy_value = new HashMap<String,PropValueUnion>();
+          Map<String,PropValueUnion> __this__attributes_copy_value_copy_value = new HashMap<String,PropValueUnion>(other_element_value_element_value.size());
           for (Map.Entry<String, PropValueUnion> other_element_value_element_value_element : other_element_value_element_value.entrySet()) {
 
             String other_element_value_element_value_element_key = other_element_value_element_value_element.getKey();
@@ -885,165 +872,165 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_aint = true;
-    builder.append(present_aint);
+    list.add(present_aint);
     if (present_aint)
-      builder.append(aint);
+      list.add(aint);
 
     boolean present_aString = true && (isSetAString());
-    builder.append(present_aString);
+    list.add(present_aString);
     if (present_aString)
-      builder.append(aString);
+      list.add(aString);
 
     boolean present_lint = true && (isSetLint());
-    builder.append(present_lint);
+    list.add(present_lint);
     if (present_lint)
-      builder.append(lint);
+      list.add(lint);
 
     boolean present_lString = true && (isSetLString());
-    builder.append(present_lString);
+    list.add(present_lString);
     if (present_lString)
-      builder.append(lString);
+      list.add(lString);
 
     boolean present_lintString = true && (isSetLintString());
-    builder.append(present_lintString);
+    list.add(present_lintString);
     if (present_lintString)
-      builder.append(lintString);
+      list.add(lintString);
 
     boolean present_mStringString = true && (isSetMStringString());
-    builder.append(present_mStringString);
+    list.add(present_mStringString);
     if (present_mStringString)
-      builder.append(mStringString);
+      list.add(mStringString);
 
     boolean present_attributes = true && (isSetAttributes());
-    builder.append(present_attributes);
+    list.add(present_attributes);
     if (present_attributes)
-      builder.append(attributes);
+      list.add(attributes);
 
     boolean present_unionField1 = true && (isSetUnionField1());
-    builder.append(present_unionField1);
+    list.add(present_unionField1);
     if (present_unionField1)
-      builder.append(unionField1);
+      list.add(unionField1);
 
     boolean present_unionField2 = true && (isSetUnionField2());
-    builder.append(present_unionField2);
+    list.add(present_unionField2);
     if (present_unionField2)
-      builder.append(unionField2);
+      list.add(unionField2);
 
     boolean present_unionField3 = true && (isSetUnionField3());
-    builder.append(present_unionField3);
+    list.add(present_unionField3);
     if (present_unionField3)
-      builder.append(unionField3);
+      list.add(unionField3);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Complex other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Complex typedOther = (Complex)other;
 
-    lastComparison = Boolean.valueOf(isSetAint()).compareTo(typedOther.isSetAint());
+    lastComparison = Boolean.valueOf(isSetAint()).compareTo(other.isSetAint());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAint()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aint, typedOther.aint);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aint, other.aint);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAString()).compareTo(typedOther.isSetAString());
+    lastComparison = Boolean.valueOf(isSetAString()).compareTo(other.isSetAString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aString, typedOther.aString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aString, other.aString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLint()).compareTo(typedOther.isSetLint());
+    lastComparison = Boolean.valueOf(isSetLint()).compareTo(other.isSetLint());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLint()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lint, typedOther.lint);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lint, other.lint);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLString()).compareTo(typedOther.isSetLString());
+    lastComparison = Boolean.valueOf(isSetLString()).compareTo(other.isSetLString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lString, typedOther.lString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lString, other.lString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLintString()).compareTo(typedOther.isSetLintString());
+    lastComparison = Boolean.valueOf(isSetLintString()).compareTo(other.isSetLintString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLintString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lintString, typedOther.lintString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lintString, other.lintString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMStringString()).compareTo(typedOther.isSetMStringString());
+    lastComparison = Boolean.valueOf(isSetMStringString()).compareTo(other.isSetMStringString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMStringString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mStringString, typedOther.mStringString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.mStringString, other.mStringString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(typedOther.isSetAttributes());
+    lastComparison = Boolean.valueOf(isSetAttributes()).compareTo(other.isSetAttributes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetAttributes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, typedOther.attributes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.attributes, other.attributes);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUnionField1()).compareTo(typedOther.isSetUnionField1());
+    lastComparison = Boolean.valueOf(isSetUnionField1()).compareTo(other.isSetUnionField1());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUnionField1()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField1, typedOther.unionField1);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField1, other.unionField1);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUnionField2()).compareTo(typedOther.isSetUnionField2());
+    lastComparison = Boolean.valueOf(isSetUnionField2()).compareTo(other.isSetUnionField2());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUnionField2()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField2, typedOther.unionField2);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField2, other.unionField2);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUnionField3()).compareTo(typedOther.isSetUnionField3());
+    lastComparison = Boolean.valueOf(isSetUnionField3()).compareTo(other.isSetUnionField3());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUnionField3()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField3, typedOther.unionField3);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unionField3, other.unionField3);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -1209,11 +1196,11 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
               {
                 org.apache.thrift.protocol.TList _list18 = iprot.readListBegin();
                 struct.lint = new ArrayList<Integer>(_list18.size);
-                for (int _i19 = 0; _i19 < _list18.size; ++_i19)
+                int _elem19;
+                for (int _i20 = 0; _i20 < _list18.size; ++_i20)
                 {
-                  int _elem20; // optional
-                  _elem20 = iprot.readI32();
-                  struct.lint.add(_elem20);
+                  _elem19 = iprot.readI32();
+                  struct.lint.add(_elem19);
                 }
                 iprot.readListEnd();
               }
@@ -1227,11 +1214,11 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
               {
                 org.apache.thrift.protocol.TList _list21 = iprot.readListBegin();
                 struct.lString = new ArrayList<String>(_list21.size);
-                for (int _i22 = 0; _i22 < _list21.size; ++_i22)
+                String _elem22;
+                for (int _i23 = 0; _i23 < _list21.size; ++_i23)
                 {
-                  String _elem23; // optional
-                  _elem23 = iprot.readString();
-                  struct.lString.add(_elem23);
+                  _elem22 = iprot.readString();
+                  struct.lString.add(_elem22);
                 }
                 iprot.readListEnd();
               }
@@ -1245,12 +1232,12 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
               {
                 org.apache.thrift.protocol.TList _list24 = iprot.readListBegin();
                 struct.lintString = new ArrayList<IntString>(_list24.size);
-                for (int _i25 = 0; _i25 < _list24.size; ++_i25)
+                IntString _elem25;
+                for (int _i26 = 0; _i26 < _list24.size; ++_i26)
                 {
-                  IntString _elem26; // optional
-                  _elem26 = new IntString();
-                  _elem26.read(iprot);
-                  struct.lintString.add(_elem26);
+                  _elem25 = new IntString();
+                  _elem25.read(iprot);
+                  struct.lintString.add(_elem25);
                 }
                 iprot.readListEnd();
               }
@@ -1264,13 +1251,13 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
               {
                 org.apache.thrift.protocol.TMap _map27 = iprot.readMapBegin();
                 struct.mStringString = new HashMap<String,String>(2*_map27.size);
-                for (int _i28 = 0; _i28 < _map27.size; ++_i28)
+                String _key28;
+                String _val29;
+                for (int _i30 = 0; _i30 < _map27.size; ++_i30)
                 {
-                  String _key29; // required
-                  String _val30; // required
-                  _key29 = iprot.readString();
-                  _val30 = iprot.readString();
-                  struct.mStringString.put(_key29, _val30);
+                  _key28 = iprot.readString();
+                  _val29 = iprot.readString();
+                  struct.mStringString.put(_key28, _val29);
                 }
                 iprot.readMapEnd();
               }
@@ -1284,38 +1271,38 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
               {
                 org.apache.thrift.protocol.TMap _map31 = iprot.readMapBegin();
                 struct.attributes = new HashMap<String,Map<String,Map<String,PropValueUnion>>>(2*_map31.size);
-                for (int _i32 = 0; _i32 < _map31.size; ++_i32)
+                String _key32;
+                Map<String,Map<String,PropValueUnion>> _val33;
+                for (int _i34 = 0; _i34 < _map31.size; ++_i34)
                 {
-                  String _key33; // required
-                  Map<String,Map<String,PropValueUnion>> _val34; // required
-                  _key33 = iprot.readString();
+                  _key32 = iprot.readString();
                   {
                     org.apache.thrift.protocol.TMap _map35 = iprot.readMapBegin();
-                    _val34 = new HashMap<String,Map<String,PropValueUnion>>(2*_map35.size);
-                    for (int _i36 = 0; _i36 < _map35.size; ++_i36)
+                    _val33 = new HashMap<String,Map<String,PropValueUnion>>(2*_map35.size);
+                    String _key36;
+                    Map<String,PropValueUnion> _val37;
+                    for (int _i38 = 0; _i38 < _map35.size; ++_i38)
                     {
-                      String _key37; // required
-                      Map<String,PropValueUnion> _val38; // required
-                      _key37 = iprot.readString();
+                      _key36 = iprot.readString();
                       {
                         org.apache.thrift.protocol.TMap _map39 = iprot.readMapBegin();
-                        _val38 = new HashMap<String,PropValueUnion>(2*_map39.size);
-                        for (int _i40 = 0; _i40 < _map39.size; ++_i40)
+                        _val37 = new HashMap<String,PropValueUnion>(2*_map39.size);
+                        String _key40;
+                        PropValueUnion _val41;
+                        for (int _i42 = 0; _i42 < _map39.size; ++_i42)
                         {
-                          String _key41; // required
-                          PropValueUnion _val42; // required
-                          _key41 = iprot.readString();
-                          _val42 = new PropValueUnion();
-                          _val42.read(iprot);
-                          _val38.put(_key41, _val42);
+                          _key40 = iprot.readString();
+                          _val41 = new PropValueUnion();
+                          _val41.read(iprot);
+                          _val37.put(_key40, _val41);
                         }
                         iprot.readMapEnd();
                       }
-                      _val34.put(_key37, _val38);
+                      _val33.put(_key36, _val37);
                     }
                     iprot.readMapEnd();
                   }
-                  struct.attributes.put(_key33, _val34);
+                  struct.attributes.put(_key32, _val33);
                 }
                 iprot.readMapEnd();
               }
@@ -1608,11 +1595,11 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
         {
           org.apache.thrift.protocol.TList _list57 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I32, iprot.readI32());
           struct.lint = new ArrayList<Integer>(_list57.size);
-          for (int _i58 = 0; _i58 < _list57.size; ++_i58)
+          int _elem58;
+          for (int _i59 = 0; _i59 < _list57.size; ++_i59)
           {
-            int _elem59; // optional
-            _elem59 = iprot.readI32();
-            struct.lint.add(_elem59);
+            _elem58 = iprot.readI32();
+            struct.lint.add(_elem58);
           }
         }
         struct.setLintIsSet(true);
@@ -1621,11 +1608,11 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
         {
           org.apache.thrift.protocol.TList _list60 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.lString = new ArrayList<String>(_list60.size);
-          for (int _i61 = 0; _i61 < _list60.size; ++_i61)
+          String _elem61;
+          for (int _i62 = 0; _i62 < _list60.size; ++_i62)
           {
-            String _elem62; // optional
-            _elem62 = iprot.readString();
-            struct.lString.add(_elem62);
+            _elem61 = iprot.readString();
+            struct.lString.add(_elem61);
           }
         }
         struct.setLStringIsSet(true);
@@ -1634,12 +1621,12 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
         {
           org.apache.thrift.protocol.TList _list63 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.lintString = new ArrayList<IntString>(_list63.size);
-          for (int _i64 = 0; _i64 < _list63.size; ++_i64)
+          IntString _elem64;
+          for (int _i65 = 0; _i65 < _list63.size; ++_i65)
           {
-            IntString _elem65; // optional
-            _elem65 = new IntString();
-            _elem65.read(iprot);
-            struct.lintString.add(_elem65);
+            _elem64 = new IntString();
+            _elem64.read(iprot);
+            struct.lintString.add(_elem64);
           }
         }
         struct.setLintStringIsSet(true);
@@ -1648,13 +1635,13 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
         {
           org.apache.thrift.protocol.TMap _map66 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.mStringString = new HashMap<String,String>(2*_map66.size);
-          for (int _i67 = 0; _i67 < _map66.size; ++_i67)
+          String _key67;
+          String _val68;
+          for (int _i69 = 0; _i69 < _map66.size; ++_i69)
           {
-            String _key68; // required
-            String _val69; // required
-            _key68 = iprot.readString();
-            _val69 = iprot.readString();
-            struct.mStringString.put(_key68, _val69);
+            _key67 = iprot.readString();
+            _val68 = iprot.readString();
+            struct.mStringString.put(_key67, _val68);
           }
         }
         struct.setMStringStringIsSet(true);
@@ -1663,36 +1650,36 @@ public class Complex implements org.apache.thrift.TBase<Complex, Complex._Fields
         {
           org.apache.thrift.protocol.TMap _map70 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.MAP, iprot.readI32());
           struct.attributes = new HashMap<String,Map<String,Map<String,PropValueUnion>>>(2*_map70.size);
-          for (int _i71 = 0; _i71 < _map70.size; ++_i71)
+          String _key71;
+          Map<String,Map<String,PropValueUnion>> _val72;
+          for (int _i73 = 0; _i73 < _map70.size; ++_i73)
           {
-            String _key72; // required
-            Map<String,Map<String,PropValueUnion>> _val73; // required
-            _key72 = iprot.readString();
+            _key71 = iprot.readString();
             {
               org.apache.thrift.protocol.TMap _map74 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.MAP, iprot.readI32());
-              _val73 = new HashMap<String,Map<String,PropValueUnion>>(2*_map74.size);
-              for (int _i75 = 0; _i75 < _map74.size; ++_i75)
+              _val72 = new HashMap<String,Map<String,PropValueUnion>>(2*_map74.size);
+              String _key75;
+              Map<String,PropValueUnion> _val76;
+              for (int _i77 = 0; _i77 < _map74.size; ++_i77)
               {
-                String _key76; // required
-                Map<String,PropValueUnion> _val77; // required
-                _key76 = iprot.readString();
+                _key75 = iprot.readString();
                 {
                   org.apache.thrift.protocol.TMap _map78 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-                  _val77 = new HashMap<String,PropValueUnion>(2*_map78.size);
-                  for (int _i79 = 0; _i79 < _map78.size; ++_i79)
+                  _val76 = new HashMap<String,PropValueUnion>(2*_map78.size);
+                  String _key79;
+                  PropValueUnion _val80;
+                  for (int _i81 = 0; _i81 < _map78.size; ++_i81)
                   {
-                    String _key80; // required
-                    PropValueUnion _val81; // required
-                    _key80 = iprot.readString();
-                    _val81 = new PropValueUnion();
-                    _val81.read(iprot);
-                    _val77.put(_key80, _val81);
+                    _key79 = iprot.readString();
+                    _val80 = new PropValueUnion();
+                    _val80.read(iprot);
+                    _val76.put(_key79, _val80);
                   }
                 }
-                _val73.put(_key76, _val77);
+                _val72.put(_key75, _val76);
               }
             }
-            struct.attributes.put(_key72, _val73);
+            struct.attributes.put(_key71, _val72);
           }
         }
         struct.setAttributesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/IntString.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/IntString.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/IntString.java
index bd580ad..b13ef82 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/IntString.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/IntString.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class IntString implements org.apache.thrift.TBase<IntString, IntString._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class IntString implements org.apache.thrift.TBase<IntString, IntString._Fields>, java.io.Serializable, Cloneable, Comparable<IntString> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("IntString");
 
   private static final org.apache.thrift.protocol.TField MYINT_FIELD_DESC = new org.apache.thrift.protocol.TField("myint", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -343,60 +347,60 @@ public class IntString implements org.apache.thrift.TBase<IntString, IntString._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_myint = true;
-    builder.append(present_myint);
+    list.add(present_myint);
     if (present_myint)
-      builder.append(myint);
+      list.add(myint);
 
     boolean present_myString = true && (isSetMyString());
-    builder.append(present_myString);
+    list.add(present_myString);
     if (present_myString)
-      builder.append(myString);
+      list.add(myString);
 
     boolean present_underscore_int = true;
-    builder.append(present_underscore_int);
+    list.add(present_underscore_int);
     if (present_underscore_int)
-      builder.append(underscore_int);
+      list.add(underscore_int);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(IntString other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    IntString typedOther = (IntString)other;
 
-    lastComparison = Boolean.valueOf(isSetMyint()).compareTo(typedOther.isSetMyint());
+    lastComparison = Boolean.valueOf(isSetMyint()).compareTo(other.isSetMyint());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMyint()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.myint, typedOther.myint);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.myint, other.myint);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMyString()).compareTo(typedOther.isSetMyString());
+    lastComparison = Boolean.valueOf(isSetMyString()).compareTo(other.isSetMyString());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMyString()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.myString, typedOther.myString);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.myString, other.myString);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetUnderscore_int()).compareTo(typedOther.isSetUnderscore_int());
+    lastComparison = Boolean.valueOf(isSetUnderscore_int()).compareTo(other.isSetUnderscore_int());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUnderscore_int()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.underscore_int, typedOther.underscore_int);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.underscore_int, other.underscore_int);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MegaStruct.java
----------------------------------------------------------------------
diff --git a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MegaStruct.java b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MegaStruct.java
index fba49e4..a394113 100644
--- a/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MegaStruct.java
+++ b/serde/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/serde2/thrift/test/MegaStruct.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.serde2.thrift.test;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruct._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruct._Fields>, java.io.Serializable, Cloneable, Comparable<MegaStruct> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("MegaStruct");
 
   private static final org.apache.thrift.protocol.TField MY_BOOL_FIELD_DESC = new org.apache.thrift.protocol.TField("my_bool", org.apache.thrift.protocol.TType.BOOL, (short)1);
@@ -205,7 +209,7 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
   private static final int __MY_64BIT_INT_ISSET_ID = 4;
   private static final int __MY_DOUBLE_ISSET_ID = 5;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.MY_BOOL,_Fields.MY_BYTE,_Fields.MY_16BIT_INT,_Fields.MY_32BIT_INT,_Fields.MY_64BIT_INT,_Fields.MY_DOUBLE,_Fields.MY_STRING,_Fields.MY_BINARY,_Fields.MY_STRING_STRING_MAP,_Fields.MY_STRING_ENUM_MAP,_Fields.MY_ENUM_STRING_MAP,_Fields.MY_ENUM_STRUCT_MAP,_Fields.MY_ENUM_STRINGLIST_MAP,_Fields.MY_ENUM_STRUCTLIST_MAP,_Fields.MY_STRINGLIST,_Fields.MY_STRUCTLIST,_Fields.MY_ENUMLIST,_Fields.MY_STRINGSET,_Fields.MY_ENUMSET,_Fields.MY_STRUCTSET};
+  private static final _Fields optionals[] = {_Fields.MY_BOOL,_Fields.MY_BYTE,_Fields.MY_16BIT_INT,_Fields.MY_32BIT_INT,_Fields.MY_64BIT_INT,_Fields.MY_DOUBLE,_Fields.MY_STRING,_Fields.MY_BINARY,_Fields.MY_STRING_STRING_MAP,_Fields.MY_STRING_ENUM_MAP,_Fields.MY_ENUM_STRING_MAP,_Fields.MY_ENUM_STRUCT_MAP,_Fields.MY_ENUM_STRINGLIST_MAP,_Fields.MY_ENUM_STRUCTLIST_MAP,_Fields.MY_STRINGLIST,_Fields.MY_STRUCTLIST,_Fields.MY_ENUMLIST,_Fields.MY_STRINGSET,_Fields.MY_ENUMSET,_Fields.MY_STRUCTSET};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -292,25 +296,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
     }
     if (other.isSetMy_binary()) {
       this.my_binary = org.apache.thrift.TBaseHelper.copyBinary(other.my_binary);
-;
     }
     if (other.isSetMy_string_string_map()) {
-      Map<String,String> __this__my_string_string_map = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.my_string_string_map.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__my_string_string_map_copy_key = other_element_key;
-
-        String __this__my_string_string_map_copy_value = other_element_value;
-
-        __this__my_string_string_map.put(__this__my_string_string_map_copy_key, __this__my_string_string_map_copy_value);
-      }
+      Map<String,String> __this__my_string_string_map = new HashMap<String,String>(other.my_string_string_map);
       this.my_string_string_map = __this__my_string_string_map;
     }
     if (other.isSetMy_string_enum_map()) {
-      Map<String,MyEnum> __this__my_string_enum_map = new HashMap<String,MyEnum>();
+      Map<String,MyEnum> __this__my_string_enum_map = new HashMap<String,MyEnum>(other.my_string_enum_map.size());
       for (Map.Entry<String, MyEnum> other_element : other.my_string_enum_map.entrySet()) {
 
         String other_element_key = other_element.getKey();
@@ -325,7 +317,7 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
       this.my_string_enum_map = __this__my_string_enum_map;
     }
     if (other.isSetMy_enum_string_map()) {
-      Map<MyEnum,String> __this__my_enum_string_map = new HashMap<MyEnum,String>();
+      Map<MyEnum,String> __this__my_enum_string_map = new HashMap<MyEnum,String>(other.my_enum_string_map.size());
       for (Map.Entry<MyEnum, String> other_element : other.my_enum_string_map.entrySet()) {
 
         MyEnum other_element_key = other_element.getKey();
@@ -340,7 +332,7 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
       this.my_enum_string_map = __this__my_enum_string_map;
     }
     if (other.isSetMy_enum_struct_map()) {
-      Map<MyEnum,MiniStruct> __this__my_enum_struct_map = new HashMap<MyEnum,MiniStruct>();
+      Map<MyEnum,MiniStruct> __this__my_enum_struct_map = new HashMap<MyEnum,MiniStruct>(other.my_enum_struct_map.size());
       for (Map.Entry<MyEnum, MiniStruct> other_element : other.my_enum_struct_map.entrySet()) {
 
         MyEnum other_element_key = other_element.getKey();
@@ -355,7 +347,7 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
       this.my_enum_struct_map = __this__my_enum_struct_map;
     }
     if (other.isSetMy_enum_stringlist_map()) {
-      Map<MyEnum,List<String>> __this__my_enum_stringlist_map = new HashMap<MyEnum,List<String>>();
+      Map<MyEnum,List<String>> __this__my_enum_stringlist_map = new HashMap<MyEnum,List<String>>(other.my_enum_stringlist_map.size());
       for (Map.Entry<MyEnum, List<String>> other_element : other.my_enum_stringlist_map.entrySet()) {
 
         MyEnum other_element_key = other_element.getKey();
@@ -363,17 +355,14 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
 
         MyEnum __this__my_enum_stringlist_map_copy_key = other_element_key;
 
-        List<String> __this__my_enum_stringlist_map_copy_value = new ArrayList<String>();
-        for (String other_element_value_element : other_element_value) {
-          __this__my_enum_stringlist_map_copy_value.add(other_element_value_element);
-        }
+        List<String> __this__my_enum_stringlist_map_copy_value = new ArrayList<String>(other_element_value);
 
         __this__my_enum_stringlist_map.put(__this__my_enum_stringlist_map_copy_key, __this__my_enum_stringlist_map_copy_value);
       }
       this.my_enum_stringlist_map = __this__my_enum_stringlist_map;
     }
     if (other.isSetMy_enum_structlist_map()) {
-      Map<MyEnum,List<MiniStruct>> __this__my_enum_structlist_map = new HashMap<MyEnum,List<MiniStruct>>();
+      Map<MyEnum,List<MiniStruct>> __this__my_enum_structlist_map = new HashMap<MyEnum,List<MiniStruct>>(other.my_enum_structlist_map.size());
       for (Map.Entry<MyEnum, List<MiniStruct>> other_element : other.my_enum_structlist_map.entrySet()) {
 
         MyEnum other_element_key = other_element.getKey();
@@ -381,7 +370,7 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
 
         MyEnum __this__my_enum_structlist_map_copy_key = other_element_key;
 
-        List<MiniStruct> __this__my_enum_structlist_map_copy_value = new ArrayList<MiniStruct>();
+        List<MiniStruct> __this__my_enum_structlist_map_copy_value = new ArrayList<MiniStruct>(other_element_value.size());
         for (MiniStruct other_element_value_element : other_element_value) {
           __this__my_enum_structlist_map_copy_value.add(new MiniStruct(other_element_value_element));
         }
@@ -391,42 +380,36 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
       this.my_enum_structlist_map = __this__my_enum_structlist_map;
     }
     if (other.isSetMy_stringlist()) {
-      List<String> __this__my_stringlist = new ArrayList<String>();
-      for (String other_element : other.my_stringlist) {
-        __this__my_stringlist.add(other_element);
-      }
+      List<String> __this__my_stringlist = new ArrayList<String>(other.my_stringlist);
       this.my_stringlist = __this__my_stringlist;
     }
     if (other.isSetMy_structlist()) {
-      List<MiniStruct> __this__my_structlist = new ArrayList<MiniStruct>();
+      List<MiniStruct> __this__my_structlist = new ArrayList<MiniStruct>(other.my_structlist.size());
       for (MiniStruct other_element : other.my_structlist) {
         __this__my_structlist.add(new MiniStruct(other_element));
       }
       this.my_structlist = __this__my_structlist;
     }
     if (other.isSetMy_enumlist()) {
-      List<MyEnum> __this__my_enumlist = new ArrayList<MyEnum>();
+      List<MyEnum> __this__my_enumlist = new ArrayList<MyEnum>(other.my_enumlist.size());
       for (MyEnum other_element : other.my_enumlist) {
         __this__my_enumlist.add(other_element);
       }
       this.my_enumlist = __this__my_enumlist;
     }
     if (other.isSetMy_stringset()) {
-      Set<String> __this__my_stringset = new HashSet<String>();
-      for (String other_element : other.my_stringset) {
-        __this__my_stringset.add(other_element);
-      }
+      Set<String> __this__my_stringset = new HashSet<String>(other.my_stringset);
       this.my_stringset = __this__my_stringset;
     }
     if (other.isSetMy_enumset()) {
-      Set<MyEnum> __this__my_enumset = new HashSet<MyEnum>();
+      Set<MyEnum> __this__my_enumset = new HashSet<MyEnum>(other.my_enumset.size());
       for (MyEnum other_element : other.my_enumset) {
         __this__my_enumset.add(other_element);
       }
       this.my_enumset = __this__my_enumset;
     }
     if (other.isSetMy_structset()) {
-      Set<MiniStruct> __this__my_structset = new HashSet<MiniStruct>();
+      Set<MiniStruct> __this__my_structset = new HashSet<MiniStruct>(other.my_structset.size());
       for (MiniStruct other_element : other.my_structset) {
         __this__my_structset.add(new MiniStruct(other_element));
       }
@@ -629,15 +612,15 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
   }
 
   public ByteBuffer bufferForMy_binary() {
-    return my_binary;
+    return org.apache.thrift.TBaseHelper.copyBinary(my_binary);
   }
 
   public void setMy_binary(byte[] my_binary) {
-    setMy_binary(my_binary == null ? (ByteBuffer)null : ByteBuffer.wrap(my_binary));
+    this.my_binary = my_binary == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(my_binary, my_binary.length));
   }
 
   public void setMy_binary(ByteBuffer my_binary) {
-    this.my_binary = my_binary;
+    this.my_binary = org.apache.thrift.TBaseHelper.copyBinary(my_binary);
   }
 
   public void unsetMy_binary() {
@@ -1567,315 +1550,315 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_my_bool = true && (isSetMy_bool());
-    builder.append(present_my_bool);
+    list.add(present_my_bool);
     if (present_my_bool)
-      builder.append(my_bool);
+      list.add(my_bool);
 
     boolean present_my_byte = true && (isSetMy_byte());
-    builder.append(present_my_byte);
+    list.add(present_my_byte);
     if (present_my_byte)
-      builder.append(my_byte);
+      list.add(my_byte);
 
     boolean present_my_16bit_int = true && (isSetMy_16bit_int());
-    builder.append(present_my_16bit_int);
+    list.add(present_my_16bit_int);
     if (present_my_16bit_int)
-      builder.append(my_16bit_int);
+      list.add(my_16bit_int);
 
     boolean present_my_32bit_int = true && (isSetMy_32bit_int());
-    builder.append(present_my_32bit_int);
+    list.add(present_my_32bit_int);
     if (present_my_32bit_int)
-      builder.append(my_32bit_int);
+      list.add(my_32bit_int);
 
     boolean present_my_64bit_int = true && (isSetMy_64bit_int());
-    builder.append(present_my_64bit_int);
+    list.add(present_my_64bit_int);
     if (present_my_64bit_int)
-      builder.append(my_64bit_int);
+      list.add(my_64bit_int);
 
     boolean present_my_double = true && (isSetMy_double());
-    builder.append(present_my_double);
+    list.add(present_my_double);
     if (present_my_double)
-      builder.append(my_double);
+      list.add(my_double);
 
     boolean present_my_string = true && (isSetMy_string());
-    builder.append(present_my_string);
+    list.add(present_my_string);
     if (present_my_string)
-      builder.append(my_string);
+      list.add(my_string);
 
     boolean present_my_binary = true && (isSetMy_binary());
-    builder.append(present_my_binary);
+    list.add(present_my_binary);
     if (present_my_binary)
-      builder.append(my_binary);
+      list.add(my_binary);
 
     boolean present_my_string_string_map = true && (isSetMy_string_string_map());
-    builder.append(present_my_string_string_map);
+    list.add(present_my_string_string_map);
     if (present_my_string_string_map)
-      builder.append(my_string_string_map);
+      list.add(my_string_string_map);
 
     boolean present_my_string_enum_map = true && (isSetMy_string_enum_map());
-    builder.append(present_my_string_enum_map);
+    list.add(present_my_string_enum_map);
     if (present_my_string_enum_map)
-      builder.append(my_string_enum_map);
+      list.add(my_string_enum_map);
 
     boolean present_my_enum_string_map = true && (isSetMy_enum_string_map());
-    builder.append(present_my_enum_string_map);
+    list.add(present_my_enum_string_map);
     if (present_my_enum_string_map)
-      builder.append(my_enum_string_map);
+      list.add(my_enum_string_map);
 
     boolean present_my_enum_struct_map = true && (isSetMy_enum_struct_map());
-    builder.append(present_my_enum_struct_map);
+    list.add(present_my_enum_struct_map);
     if (present_my_enum_struct_map)
-      builder.append(my_enum_struct_map);
+      list.add(my_enum_struct_map);
 
     boolean present_my_enum_stringlist_map = true && (isSetMy_enum_stringlist_map());
-    builder.append(present_my_enum_stringlist_map);
+    list.add(present_my_enum_stringlist_map);
     if (present_my_enum_stringlist_map)
-      builder.append(my_enum_stringlist_map);
+      list.add(my_enum_stringlist_map);
 
     boolean present_my_enum_structlist_map = true && (isSetMy_enum_structlist_map());
-    builder.append(present_my_enum_structlist_map);
+    list.add(present_my_enum_structlist_map);
     if (present_my_enum_structlist_map)
-      builder.append(my_enum_structlist_map);
+      list.add(my_enum_structlist_map);
 
     boolean present_my_stringlist = true && (isSetMy_stringlist());
-    builder.append(present_my_stringlist);
+    list.add(present_my_stringlist);
     if (present_my_stringlist)
-      builder.append(my_stringlist);
+      list.add(my_stringlist);
 
     boolean present_my_structlist = true && (isSetMy_structlist());
-    builder.append(present_my_structlist);
+    list.add(present_my_structlist);
     if (present_my_structlist)
-      builder.append(my_structlist);
+      list.add(my_structlist);
 
     boolean present_my_enumlist = true && (isSetMy_enumlist());
-    builder.append(present_my_enumlist);
+    list.add(present_my_enumlist);
     if (present_my_enumlist)
-      builder.append(my_enumlist);
+      list.add(my_enumlist);
 
     boolean present_my_stringset = true && (isSetMy_stringset());
-    builder.append(present_my_stringset);
+    list.add(present_my_stringset);
     if (present_my_stringset)
-      builder.append(my_stringset);
+      list.add(my_stringset);
 
     boolean present_my_enumset = true && (isSetMy_enumset());
-    builder.append(present_my_enumset);
+    list.add(present_my_enumset);
     if (present_my_enumset)
-      builder.append(my_enumset);
+      list.add(my_enumset);
 
     boolean present_my_structset = true && (isSetMy_structset());
-    builder.append(present_my_structset);
+    list.add(present_my_structset);
     if (present_my_structset)
-      builder.append(my_structset);
+      list.add(my_structset);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(MegaStruct other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    MegaStruct typedOther = (MegaStruct)other;
 
-    lastComparison = Boolean.valueOf(isSetMy_bool()).compareTo(typedOther.isSetMy_bool());
+    lastComparison = Boolean.valueOf(isSetMy_bool()).compareTo(other.isSetMy_bool());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_bool()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_bool, typedOther.my_bool);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_bool, other.my_bool);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_byte()).compareTo(typedOther.isSetMy_byte());
+    lastComparison = Boolean.valueOf(isSetMy_byte()).compareTo(other.isSetMy_byte());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_byte()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_byte, typedOther.my_byte);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_byte, other.my_byte);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_16bit_int()).compareTo(typedOther.isSetMy_16bit_int());
+    lastComparison = Boolean.valueOf(isSetMy_16bit_int()).compareTo(other.isSetMy_16bit_int());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_16bit_int()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_16bit_int, typedOther.my_16bit_int);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_16bit_int, other.my_16bit_int);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_32bit_int()).compareTo(typedOther.isSetMy_32bit_int());
+    lastComparison = Boolean.valueOf(isSetMy_32bit_int()).compareTo(other.isSetMy_32bit_int());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_32bit_int()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_32bit_int, typedOther.my_32bit_int);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_32bit_int, other.my_32bit_int);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_64bit_int()).compareTo(typedOther.isSetMy_64bit_int());
+    lastComparison = Boolean.valueOf(isSetMy_64bit_int()).compareTo(other.isSetMy_64bit_int());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_64bit_int()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_64bit_int, typedOther.my_64bit_int);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_64bit_int, other.my_64bit_int);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_double()).compareTo(typedOther.isSetMy_double());
+    lastComparison = Boolean.valueOf(isSetMy_double()).compareTo(other.isSetMy_double());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_double()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_double, typedOther.my_double);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_double, other.my_double);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_string()).compareTo(typedOther.isSetMy_string());
+    lastComparison = Boolean.valueOf(isSetMy_string()).compareTo(other.isSetMy_string());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_string()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string, typedOther.my_string);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string, other.my_string);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_binary()).compareTo(typedOther.isSetMy_binary());
+    lastComparison = Boolean.valueOf(isSetMy_binary()).compareTo(other.isSetMy_binary());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_binary()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_binary, typedOther.my_binary);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_binary, other.my_binary);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_string_string_map()).compareTo(typedOther.isSetMy_string_string_map());
+    lastComparison = Boolean.valueOf(isSetMy_string_string_map()).compareTo(other.isSetMy_string_string_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_string_string_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string_string_map, typedOther.my_string_string_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string_string_map, other.my_string_string_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_string_enum_map()).compareTo(typedOther.isSetMy_string_enum_map());
+    lastComparison = Boolean.valueOf(isSetMy_string_enum_map()).compareTo(other.isSetMy_string_enum_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_string_enum_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string_enum_map, typedOther.my_string_enum_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_string_enum_map, other.my_string_enum_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enum_string_map()).compareTo(typedOther.isSetMy_enum_string_map());
+    lastComparison = Boolean.valueOf(isSetMy_enum_string_map()).compareTo(other.isSetMy_enum_string_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enum_string_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_string_map, typedOther.my_enum_string_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_string_map, other.my_enum_string_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enum_struct_map()).compareTo(typedOther.isSetMy_enum_struct_map());
+    lastComparison = Boolean.valueOf(isSetMy_enum_struct_map()).compareTo(other.isSetMy_enum_struct_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enum_struct_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_struct_map, typedOther.my_enum_struct_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_struct_map, other.my_enum_struct_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enum_stringlist_map()).compareTo(typedOther.isSetMy_enum_stringlist_map());
+    lastComparison = Boolean.valueOf(isSetMy_enum_stringlist_map()).compareTo(other.isSetMy_enum_stringlist_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enum_stringlist_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_stringlist_map, typedOther.my_enum_stringlist_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_stringlist_map, other.my_enum_stringlist_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enum_structlist_map()).compareTo(typedOther.isSetMy_enum_structlist_map());
+    lastComparison = Boolean.valueOf(isSetMy_enum_structlist_map()).compareTo(other.isSetMy_enum_structlist_map());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enum_structlist_map()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_structlist_map, typedOther.my_enum_structlist_map);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enum_structlist_map, other.my_enum_structlist_map);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_stringlist()).compareTo(typedOther.isSetMy_stringlist());
+    lastComparison = Boolean.valueOf(isSetMy_stringlist()).compareTo(other.isSetMy_stringlist());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_stringlist()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_stringlist, typedOther.my_stringlist);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_stringlist, other.my_stringlist);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_structlist()).compareTo(typedOther.isSetMy_structlist());
+    lastComparison = Boolean.valueOf(isSetMy_structlist()).compareTo(other.isSetMy_structlist());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_structlist()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_structlist, typedOther.my_structlist);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_structlist, other.my_structlist);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enumlist()).compareTo(typedOther.isSetMy_enumlist());
+    lastComparison = Boolean.valueOf(isSetMy_enumlist()).compareTo(other.isSetMy_enumlist());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enumlist()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enumlist, typedOther.my_enumlist);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enumlist, other.my_enumlist);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_stringset()).compareTo(typedOther.isSetMy_stringset());
+    lastComparison = Boolean.valueOf(isSetMy_stringset()).compareTo(other.isSetMy_stringset());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_stringset()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_stringset, typedOther.my_stringset);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_stringset, other.my_stringset);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_enumset()).compareTo(typedOther.isSetMy_enumset());
+    lastComparison = Boolean.valueOf(isSetMy_enumset()).compareTo(other.isSetMy_enumset());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_enumset()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enumset, typedOther.my_enumset);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_enumset, other.my_enumset);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetMy_structset()).compareTo(typedOther.isSetMy_structset());
+    lastComparison = Boolean.valueOf(isSetMy_structset()).compareTo(other.isSetMy_structset());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMy_structset()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_structset, typedOther.my_structset);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.my_structset, other.my_structset);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -2189,13 +2172,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map0 = iprot.readMapBegin();
                 struct.my_string_string_map = new HashMap<String,String>(2*_map0.size);
-                for (int _i1 = 0; _i1 < _map0.size; ++_i1)
+                String _key1;
+                String _val2;
+                for (int _i3 = 0; _i3 < _map0.size; ++_i3)
                 {
-                  String _key2; // required
-                  String _val3; // required
-                  _key2 = iprot.readString();
-                  _val3 = iprot.readString();
-                  struct.my_string_string_map.put(_key2, _val3);
+                  _key1 = iprot.readString();
+                  _val2 = iprot.readString();
+                  struct.my_string_string_map.put(_key1, _val2);
                 }
                 iprot.readMapEnd();
               }
@@ -2209,13 +2192,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map4 = iprot.readMapBegin();
                 struct.my_string_enum_map = new HashMap<String,MyEnum>(2*_map4.size);
-                for (int _i5 = 0; _i5 < _map4.size; ++_i5)
+                String _key5;
+                MyEnum _val6;
+                for (int _i7 = 0; _i7 < _map4.size; ++_i7)
                 {
-                  String _key6; // required
-                  MyEnum _val7; // required
-                  _key6 = iprot.readString();
-                  _val7 = MyEnum.findByValue(iprot.readI32());
-                  struct.my_string_enum_map.put(_key6, _val7);
+                  _key5 = iprot.readString();
+                  _val6 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+                  struct.my_string_enum_map.put(_key5, _val6);
                 }
                 iprot.readMapEnd();
               }
@@ -2229,13 +2212,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map8 = iprot.readMapBegin();
                 struct.my_enum_string_map = new HashMap<MyEnum,String>(2*_map8.size);
-                for (int _i9 = 0; _i9 < _map8.size; ++_i9)
+                MyEnum _key9;
+                String _val10;
+                for (int _i11 = 0; _i11 < _map8.size; ++_i11)
                 {
-                  MyEnum _key10; // required
-                  String _val11; // required
-                  _key10 = MyEnum.findByValue(iprot.readI32());
-                  _val11 = iprot.readString();
-                  struct.my_enum_string_map.put(_key10, _val11);
+                  _key9 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+                  _val10 = iprot.readString();
+                  struct.my_enum_string_map.put(_key9, _val10);
                 }
                 iprot.readMapEnd();
               }
@@ -2249,14 +2232,14 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map12 = iprot.readMapBegin();
                 struct.my_enum_struct_map = new HashMap<MyEnum,MiniStruct>(2*_map12.size);
-                for (int _i13 = 0; _i13 < _map12.size; ++_i13)
+                MyEnum _key13;
+                MiniStruct _val14;
+                for (int _i15 = 0; _i15 < _map12.size; ++_i15)
                 {
-                  MyEnum _key14; // required
-                  MiniStruct _val15; // required
-                  _key14 = MyEnum.findByValue(iprot.readI32());
-                  _val15 = new MiniStruct();
-                  _val15.read(iprot);
-                  struct.my_enum_struct_map.put(_key14, _val15);
+                  _key13 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+                  _val14 = new MiniStruct();
+                  _val14.read(iprot);
+                  struct.my_enum_struct_map.put(_key13, _val14);
                 }
                 iprot.readMapEnd();
               }
@@ -2270,23 +2253,23 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map16 = iprot.readMapBegin();
                 struct.my_enum_stringlist_map = new HashMap<MyEnum,List<String>>(2*_map16.size);
-                for (int _i17 = 0; _i17 < _map16.size; ++_i17)
+                MyEnum _key17;
+                List<String> _val18;
+                for (int _i19 = 0; _i19 < _map16.size; ++_i19)
                 {
-                  MyEnum _key18; // required
-                  List<String> _val19; // required
-                  _key18 = MyEnum.findByValue(iprot.readI32());
+                  _key17 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
                   {
                     org.apache.thrift.protocol.TList _list20 = iprot.readListBegin();
-                    _val19 = new ArrayList<String>(_list20.size);
-                    for (int _i21 = 0; _i21 < _list20.size; ++_i21)
+                    _val18 = new ArrayList<String>(_list20.size);
+                    String _elem21;
+                    for (int _i22 = 0; _i22 < _list20.size; ++_i22)
                     {
-                      String _elem22; // optional
-                      _elem22 = iprot.readString();
-                      _val19.add(_elem22);
+                      _elem21 = iprot.readString();
+                      _val18.add(_elem21);
                     }
                     iprot.readListEnd();
                   }
-                  struct.my_enum_stringlist_map.put(_key18, _val19);
+                  struct.my_enum_stringlist_map.put(_key17, _val18);
                 }
                 iprot.readMapEnd();
               }
@@ -2300,24 +2283,24 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TMap _map23 = iprot.readMapBegin();
                 struct.my_enum_structlist_map = new HashMap<MyEnum,List<MiniStruct>>(2*_map23.size);
-                for (int _i24 = 0; _i24 < _map23.size; ++_i24)
+                MyEnum _key24;
+                List<MiniStruct> _val25;
+                for (int _i26 = 0; _i26 < _map23.size; ++_i26)
                 {
-                  MyEnum _key25; // required
-                  List<MiniStruct> _val26; // required
-                  _key25 = MyEnum.findByValue(iprot.readI32());
+                  _key24 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
                   {
                     org.apache.thrift.protocol.TList _list27 = iprot.readListBegin();
-                    _val26 = new ArrayList<MiniStruct>(_list27.size);
-                    for (int _i28 = 0; _i28 < _list27.size; ++_i28)
+                    _val25 = new ArrayList<MiniStruct>(_list27.size);
+                    MiniStruct _elem28;
+                    for (int _i29 = 0; _i29 < _list27.size; ++_i29)
                     {
-                      MiniStruct _elem29; // optional
-                      _elem29 = new MiniStruct();
-                      _elem29.read(iprot);
-                      _val26.add(_elem29);
+                      _elem28 = new MiniStruct();
+                      _elem28.read(iprot);
+                      _val25.add(_elem28);
                     }
                     iprot.readListEnd();
                   }
-                  struct.my_enum_structlist_map.put(_key25, _val26);
+                  struct.my_enum_structlist_map.put(_key24, _val25);
                 }
                 iprot.readMapEnd();
               }
@@ -2331,11 +2314,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TList _list30 = iprot.readListBegin();
                 struct.my_stringlist = new ArrayList<String>(_list30.size);
-                for (int _i31 = 0; _i31 < _list30.size; ++_i31)
+                String _elem31;
+                for (int _i32 = 0; _i32 < _list30.size; ++_i32)
                 {
-                  String _elem32; // optional
-                  _elem32 = iprot.readString();
-                  struct.my_stringlist.add(_elem32);
+                  _elem31 = iprot.readString();
+                  struct.my_stringlist.add(_elem31);
                 }
                 iprot.readListEnd();
               }
@@ -2349,12 +2332,12 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TList _list33 = iprot.readListBegin();
                 struct.my_structlist = new ArrayList<MiniStruct>(_list33.size);
-                for (int _i34 = 0; _i34 < _list33.size; ++_i34)
+                MiniStruct _elem34;
+                for (int _i35 = 0; _i35 < _list33.size; ++_i35)
                 {
-                  MiniStruct _elem35; // optional
-                  _elem35 = new MiniStruct();
-                  _elem35.read(iprot);
-                  struct.my_structlist.add(_elem35);
+                  _elem34 = new MiniStruct();
+                  _elem34.read(iprot);
+                  struct.my_structlist.add(_elem34);
                 }
                 iprot.readListEnd();
               }
@@ -2368,11 +2351,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TList _list36 = iprot.readListBegin();
                 struct.my_enumlist = new ArrayList<MyEnum>(_list36.size);
-                for (int _i37 = 0; _i37 < _list36.size; ++_i37)
+                MyEnum _elem37;
+                for (int _i38 = 0; _i38 < _list36.size; ++_i38)
                 {
-                  MyEnum _elem38; // optional
-                  _elem38 = MyEnum.findByValue(iprot.readI32());
-                  struct.my_enumlist.add(_elem38);
+                  _elem37 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+                  struct.my_enumlist.add(_elem37);
                 }
                 iprot.readListEnd();
               }
@@ -2386,11 +2369,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TSet _set39 = iprot.readSetBegin();
                 struct.my_stringset = new HashSet<String>(2*_set39.size);
-                for (int _i40 = 0; _i40 < _set39.size; ++_i40)
+                String _elem40;
+                for (int _i41 = 0; _i41 < _set39.size; ++_i41)
                 {
-                  String _elem41; // optional
-                  _elem41 = iprot.readString();
-                  struct.my_stringset.add(_elem41);
+                  _elem40 = iprot.readString();
+                  struct.my_stringset.add(_elem40);
                 }
                 iprot.readSetEnd();
               }
@@ -2404,11 +2387,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TSet _set42 = iprot.readSetBegin();
                 struct.my_enumset = new HashSet<MyEnum>(2*_set42.size);
-                for (int _i43 = 0; _i43 < _set42.size; ++_i43)
+                MyEnum _elem43;
+                for (int _i44 = 0; _i44 < _set42.size; ++_i44)
                 {
-                  MyEnum _elem44; // optional
-                  _elem44 = MyEnum.findByValue(iprot.readI32());
-                  struct.my_enumset.add(_elem44);
+                  _elem43 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+                  struct.my_enumset.add(_elem43);
                 }
                 iprot.readSetEnd();
               }
@@ -2422,12 +2405,12 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
               {
                 org.apache.thrift.protocol.TSet _set45 = iprot.readSetBegin();
                 struct.my_structset = new HashSet<MiniStruct>(2*_set45.size);
-                for (int _i46 = 0; _i46 < _set45.size; ++_i46)
+                MiniStruct _elem46;
+                for (int _i47 = 0; _i47 < _set45.size; ++_i47)
                 {
-                  MiniStruct _elem47; // optional
-                  _elem47 = new MiniStruct();
-                  _elem47.read(iprot);
-                  struct.my_structset.add(_elem47);
+                  _elem46 = new MiniStruct();
+                  _elem46.read(iprot);
+                  struct.my_structset.add(_elem46);
                 }
                 iprot.readSetEnd();
               }
@@ -2952,13 +2935,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map76 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.my_string_string_map = new HashMap<String,String>(2*_map76.size);
-          for (int _i77 = 0; _i77 < _map76.size; ++_i77)
+          String _key77;
+          String _val78;
+          for (int _i79 = 0; _i79 < _map76.size; ++_i79)
           {
-            String _key78; // required
-            String _val79; // required
-            _key78 = iprot.readString();
-            _val79 = iprot.readString();
-            struct.my_string_string_map.put(_key78, _val79);
+            _key77 = iprot.readString();
+            _val78 = iprot.readString();
+            struct.my_string_string_map.put(_key77, _val78);
           }
         }
         struct.setMy_string_string_mapIsSet(true);
@@ -2967,13 +2950,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map80 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.I32, iprot.readI32());
           struct.my_string_enum_map = new HashMap<String,MyEnum>(2*_map80.size);
-          for (int _i81 = 0; _i81 < _map80.size; ++_i81)
+          String _key81;
+          MyEnum _val82;
+          for (int _i83 = 0; _i83 < _map80.size; ++_i83)
           {
-            String _key82; // required
-            MyEnum _val83; // required
-            _key82 = iprot.readString();
-            _val83 = MyEnum.findByValue(iprot.readI32());
-            struct.my_string_enum_map.put(_key82, _val83);
+            _key81 = iprot.readString();
+            _val82 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+            struct.my_string_enum_map.put(_key81, _val82);
           }
         }
         struct.setMy_string_enum_mapIsSet(true);
@@ -2982,13 +2965,13 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map84 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.I32, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.my_enum_string_map = new HashMap<MyEnum,String>(2*_map84.size);
-          for (int _i85 = 0; _i85 < _map84.size; ++_i85)
+          MyEnum _key85;
+          String _val86;
+          for (int _i87 = 0; _i87 < _map84.size; ++_i87)
           {
-            MyEnum _key86; // required
-            String _val87; // required
-            _key86 = MyEnum.findByValue(iprot.readI32());
-            _val87 = iprot.readString();
-            struct.my_enum_string_map.put(_key86, _val87);
+            _key85 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+            _val86 = iprot.readString();
+            struct.my_enum_string_map.put(_key85, _val86);
           }
         }
         struct.setMy_enum_string_mapIsSet(true);
@@ -2997,14 +2980,14 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map88 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.I32, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.my_enum_struct_map = new HashMap<MyEnum,MiniStruct>(2*_map88.size);
-          for (int _i89 = 0; _i89 < _map88.size; ++_i89)
+          MyEnum _key89;
+          MiniStruct _val90;
+          for (int _i91 = 0; _i91 < _map88.size; ++_i91)
           {
-            MyEnum _key90; // required
-            MiniStruct _val91; // required
-            _key90 = MyEnum.findByValue(iprot.readI32());
-            _val91 = new MiniStruct();
-            _val91.read(iprot);
-            struct.my_enum_struct_map.put(_key90, _val91);
+            _key89 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+            _val90 = new MiniStruct();
+            _val90.read(iprot);
+            struct.my_enum_struct_map.put(_key89, _val90);
           }
         }
         struct.setMy_enum_struct_mapIsSet(true);
@@ -3013,22 +2996,22 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map92 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.I32, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.my_enum_stringlist_map = new HashMap<MyEnum,List<String>>(2*_map92.size);
-          for (int _i93 = 0; _i93 < _map92.size; ++_i93)
+          MyEnum _key93;
+          List<String> _val94;
+          for (int _i95 = 0; _i95 < _map92.size; ++_i95)
           {
-            MyEnum _key94; // required
-            List<String> _val95; // required
-            _key94 = MyEnum.findByValue(iprot.readI32());
+            _key93 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
             {
               org.apache.thrift.protocol.TList _list96 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-              _val95 = new ArrayList<String>(_list96.size);
-              for (int _i97 = 0; _i97 < _list96.size; ++_i97)
+              _val94 = new ArrayList<String>(_list96.size);
+              String _elem97;
+              for (int _i98 = 0; _i98 < _list96.size; ++_i98)
               {
-                String _elem98; // optional
-                _elem98 = iprot.readString();
-                _val95.add(_elem98);
+                _elem97 = iprot.readString();
+                _val94.add(_elem97);
               }
             }
-            struct.my_enum_stringlist_map.put(_key94, _val95);
+            struct.my_enum_stringlist_map.put(_key93, _val94);
           }
         }
         struct.setMy_enum_stringlist_mapIsSet(true);
@@ -3037,23 +3020,23 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TMap _map99 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.I32, org.apache.thrift.protocol.TType.LIST, iprot.readI32());
           struct.my_enum_structlist_map = new HashMap<MyEnum,List<MiniStruct>>(2*_map99.size);
-          for (int _i100 = 0; _i100 < _map99.size; ++_i100)
+          MyEnum _key100;
+          List<MiniStruct> _val101;
+          for (int _i102 = 0; _i102 < _map99.size; ++_i102)
           {
-            MyEnum _key101; // required
-            List<MiniStruct> _val102; // required
-            _key101 = MyEnum.findByValue(iprot.readI32());
+            _key100 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
             {
               org.apache.thrift.protocol.TList _list103 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-              _val102 = new ArrayList<MiniStruct>(_list103.size);
-              for (int _i104 = 0; _i104 < _list103.size; ++_i104)
+              _val101 = new ArrayList<MiniStruct>(_list103.size);
+              MiniStruct _elem104;
+              for (int _i105 = 0; _i105 < _list103.size; ++_i105)
               {
-                MiniStruct _elem105; // optional
-                _elem105 = new MiniStruct();
-                _elem105.read(iprot);
-                _val102.add(_elem105);
+                _elem104 = new MiniStruct();
+                _elem104.read(iprot);
+                _val101.add(_elem104);
               }
             }
-            struct.my_enum_structlist_map.put(_key101, _val102);
+            struct.my_enum_structlist_map.put(_key100, _val101);
           }
         }
         struct.setMy_enum_structlist_mapIsSet(true);
@@ -3062,11 +3045,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TList _list106 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.my_stringlist = new ArrayList<String>(_list106.size);
-          for (int _i107 = 0; _i107 < _list106.size; ++_i107)
+          String _elem107;
+          for (int _i108 = 0; _i108 < _list106.size; ++_i108)
           {
-            String _elem108; // optional
-            _elem108 = iprot.readString();
-            struct.my_stringlist.add(_elem108);
+            _elem107 = iprot.readString();
+            struct.my_stringlist.add(_elem107);
           }
         }
         struct.setMy_stringlistIsSet(true);
@@ -3075,12 +3058,12 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TList _list109 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.my_structlist = new ArrayList<MiniStruct>(_list109.size);
-          for (int _i110 = 0; _i110 < _list109.size; ++_i110)
+          MiniStruct _elem110;
+          for (int _i111 = 0; _i111 < _list109.size; ++_i111)
           {
-            MiniStruct _elem111; // optional
-            _elem111 = new MiniStruct();
-            _elem111.read(iprot);
-            struct.my_structlist.add(_elem111);
+            _elem110 = new MiniStruct();
+            _elem110.read(iprot);
+            struct.my_structlist.add(_elem110);
           }
         }
         struct.setMy_structlistIsSet(true);
@@ -3089,11 +3072,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TList _list112 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I32, iprot.readI32());
           struct.my_enumlist = new ArrayList<MyEnum>(_list112.size);
-          for (int _i113 = 0; _i113 < _list112.size; ++_i113)
+          MyEnum _elem113;
+          for (int _i114 = 0; _i114 < _list112.size; ++_i114)
           {
-            MyEnum _elem114; // optional
-            _elem114 = MyEnum.findByValue(iprot.readI32());
-            struct.my_enumlist.add(_elem114);
+            _elem113 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+            struct.my_enumlist.add(_elem113);
           }
         }
         struct.setMy_enumlistIsSet(true);
@@ -3102,11 +3085,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TSet _set115 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.my_stringset = new HashSet<String>(2*_set115.size);
-          for (int _i116 = 0; _i116 < _set115.size; ++_i116)
+          String _elem116;
+          for (int _i117 = 0; _i117 < _set115.size; ++_i117)
           {
-            String _elem117; // optional
-            _elem117 = iprot.readString();
-            struct.my_stringset.add(_elem117);
+            _elem116 = iprot.readString();
+            struct.my_stringset.add(_elem116);
           }
         }
         struct.setMy_stringsetIsSet(true);
@@ -3115,11 +3098,11 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TSet _set118 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I32, iprot.readI32());
           struct.my_enumset = new HashSet<MyEnum>(2*_set118.size);
-          for (int _i119 = 0; _i119 < _set118.size; ++_i119)
+          MyEnum _elem119;
+          for (int _i120 = 0; _i120 < _set118.size; ++_i120)
           {
-            MyEnum _elem120; // optional
-            _elem120 = MyEnum.findByValue(iprot.readI32());
-            struct.my_enumset.add(_elem120);
+            _elem119 = org.apache.hadoop.hive.serde2.thrift.test.MyEnum.findByValue(iprot.readI32());
+            struct.my_enumset.add(_elem119);
           }
         }
         struct.setMy_enumsetIsSet(true);
@@ -3128,12 +3111,12 @@ public class MegaStruct implements org.apache.thrift.TBase<MegaStruct, MegaStruc
         {
           org.apache.thrift.protocol.TSet _set121 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.my_structset = new HashSet<MiniStruct>(2*_set121.size);
-          for (int _i122 = 0; _i122 < _set121.size; ++_i122)
+          MiniStruct _elem122;
+          for (int _i123 = 0; _i123 < _set121.size; ++_i123)
           {
-            MiniStruct _elem123; // optional
-            _elem123 = new MiniStruct();
-            _elem123.read(iprot);
-            struct.my_structset.add(_elem123);
+            _elem122 = new MiniStruct();
+            _elem122.read(iprot);
+            struct.my_structset.add(_elem122);
           }
         }
         struct.setMy_structsetIsSet(true);


[41/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionRequest.java
index 939c15a..c18e819 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequest, CompactionRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequest, CompactionRequest._Fields>, java.io.Serializable, Cloneable, Comparable<CompactionRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CompactionRequest");
 
   private static final org.apache.thrift.protocol.TField DBNAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbname", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -127,7 +131,7 @@ public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequ
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.PARTITIONNAME,_Fields.RUNAS};
+  private static final _Fields optionals[] = {_Fields.PARTITIONNAME,_Fields.RUNAS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -466,90 +470,90 @@ public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequ
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbname = true && (isSetDbname());
-    builder.append(present_dbname);
+    list.add(present_dbname);
     if (present_dbname)
-      builder.append(dbname);
+      list.add(dbname);
 
     boolean present_tablename = true && (isSetTablename());
-    builder.append(present_tablename);
+    list.add(present_tablename);
     if (present_tablename)
-      builder.append(tablename);
+      list.add(tablename);
 
     boolean present_partitionname = true && (isSetPartitionname());
-    builder.append(present_partitionname);
+    list.add(present_partitionname);
     if (present_partitionname)
-      builder.append(partitionname);
+      list.add(partitionname);
 
     boolean present_type = true && (isSetType());
-    builder.append(present_type);
+    list.add(present_type);
     if (present_type)
-      builder.append(type.getValue());
+      list.add(type.getValue());
 
     boolean present_runas = true && (isSetRunas());
-    builder.append(present_runas);
+    list.add(present_runas);
     if (present_runas)
-      builder.append(runas);
+      list.add(runas);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(CompactionRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    CompactionRequest typedOther = (CompactionRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(typedOther.isSetDbname());
+    lastComparison = Boolean.valueOf(isSetDbname()).compareTo(other.isSetDbname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, typedOther.dbname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbname, other.dbname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(typedOther.isSetTablename());
+    lastComparison = Boolean.valueOf(isSetTablename()).compareTo(other.isSetTablename());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTablename()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, typedOther.tablename);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tablename, other.tablename);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(typedOther.isSetPartitionname());
+    lastComparison = Boolean.valueOf(isSetPartitionname()).compareTo(other.isSetPartitionname());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitionname()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, typedOther.partitionname);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitionname, other.partitionname);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetType()).compareTo(typedOther.isSetType());
+    lastComparison = Boolean.valueOf(isSetType()).compareTo(other.isSetType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, typedOther.type);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.type, other.type);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetRunas()).compareTo(typedOther.isSetRunas());
+    lastComparison = Boolean.valueOf(isSetRunas()).compareTo(other.isSetRunas());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetRunas()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runas, typedOther.runas);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.runas, other.runas);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -698,7 +702,7 @@ public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequ
             break;
           case 4: // TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.type = CompactionType.findByValue(iprot.readI32());
+              struct.type = org.apache.hadoop.hive.metastore.api.CompactionType.findByValue(iprot.readI32());
               struct.setTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -797,7 +801,7 @@ public class CompactionRequest implements org.apache.thrift.TBase<CompactionRequ
       struct.setDbnameIsSet(true);
       struct.tablename = iprot.readString();
       struct.setTablenameIsSet(true);
-      struct.type = CompactionType.findByValue(iprot.readI32());
+      struct.type = org.apache.hadoop.hive.metastore.api.CompactionType.findByValue(iprot.readI32());
       struct.setTypeIsSet(true);
       BitSet incoming = iprot.readBitSet(2);
       if (incoming.get(0)) {

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionType.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionType.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionType.java
index e4ecbcc..09474ee 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionType.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CompactionType.java
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ConfigValSecurityException.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ConfigValSecurityException.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ConfigValSecurityException.java
index bdcf21d..2f57fa9 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ConfigValSecurityException.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ConfigValSecurityException.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class ConfigValSecurityException extends TException implements org.apache.thrift.TBase<ConfigValSecurityException, ConfigValSecurityException._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class ConfigValSecurityException extends TException implements org.apache.thrift.TBase<ConfigValSecurityException, ConfigValSecurityException._Fields>, java.io.Serializable, Cloneable, Comparable<ConfigValSecurityException> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("ConfigValSecurityException");
 
   private static final org.apache.thrift.protocol.TField MESSAGE_FIELD_DESC = new org.apache.thrift.protocol.TField("message", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -225,30 +229,30 @@ public class ConfigValSecurityException extends TException implements org.apache
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_message = true && (isSetMessage());
-    builder.append(present_message);
+    list.add(present_message);
     if (present_message)
-      builder.append(message);
+      list.add(message);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(ConfigValSecurityException other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    ConfigValSecurityException typedOther = (ConfigValSecurityException)other;
 
-    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(typedOther.isSetMessage());
+    lastComparison = Boolean.valueOf(isSetMessage()).compareTo(other.isSetMessage());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetMessage()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, typedOther.message);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.message, other.message);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CurrentNotificationEventId.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CurrentNotificationEventId.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CurrentNotificationEventId.java
index 8b8e5c4..a873e55 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CurrentNotificationEventId.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CurrentNotificationEventId.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class CurrentNotificationEventId implements org.apache.thrift.TBase<CurrentNotificationEventId, CurrentNotificationEventId._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class CurrentNotificationEventId implements org.apache.thrift.TBase<CurrentNotificationEventId, CurrentNotificationEventId._Fields>, java.io.Serializable, Cloneable, Comparable<CurrentNotificationEventId> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("CurrentNotificationEventId");
 
   private static final org.apache.thrift.protocol.TField EVENT_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("eventId", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class CurrentNotificationEventId implements org.apache.thrift.TBase<Curre
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_eventId = true;
-    builder.append(present_eventId);
+    list.add(present_eventId);
     if (present_eventId)
-      builder.append(eventId);
+      list.add(eventId);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(CurrentNotificationEventId other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    CurrentNotificationEventId typedOther = (CurrentNotificationEventId)other;
 
-    lastComparison = Boolean.valueOf(isSetEventId()).compareTo(typedOther.isSetEventId());
+    lastComparison = Boolean.valueOf(isSetEventId()).compareTo(other.isSetEventId());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEventId()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventId, typedOther.eventId);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.eventId, other.eventId);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Database.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Database.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Database.java
index c3c531d..f1a6bed 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Database.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Database.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Database implements org.apache.thrift.TBase<Database, Database._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Database implements org.apache.thrift.TBase<Database, Database._Fields>, java.io.Serializable, Cloneable, Comparable<Database> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Database");
 
   private static final org.apache.thrift.protocol.TField NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("name", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -137,7 +141,7 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.PRIVILEGES,_Fields.OWNER_NAME,_Fields.OWNER_TYPE};
+  private static final _Fields optionals[] = {_Fields.PRIVILEGES,_Fields.OWNER_NAME,_Fields.OWNER_TYPE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -191,18 +195,7 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
       this.locationUri = other.locationUri;
     }
     if (other.isSetParameters()) {
-      Map<String,String> __this__parameters = new HashMap<String,String>();
-      for (Map.Entry<String, String> other_element : other.parameters.entrySet()) {
-
-        String other_element_key = other_element.getKey();
-        String other_element_value = other_element.getValue();
-
-        String __this__parameters_copy_key = other_element_key;
-
-        String __this__parameters_copy_value = other_element_value;
-
-        __this__parameters.put(__this__parameters_copy_key, __this__parameters_copy_value);
-      }
+      Map<String,String> __this__parameters = new HashMap<String,String>(other.parameters);
       this.parameters = __this__parameters;
     }
     if (other.isSetPrivileges()) {
@@ -605,120 +598,120 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_name = true && (isSetName());
-    builder.append(present_name);
+    list.add(present_name);
     if (present_name)
-      builder.append(name);
+      list.add(name);
 
     boolean present_description = true && (isSetDescription());
-    builder.append(present_description);
+    list.add(present_description);
     if (present_description)
-      builder.append(description);
+      list.add(description);
 
     boolean present_locationUri = true && (isSetLocationUri());
-    builder.append(present_locationUri);
+    list.add(present_locationUri);
     if (present_locationUri)
-      builder.append(locationUri);
+      list.add(locationUri);
 
     boolean present_parameters = true && (isSetParameters());
-    builder.append(present_parameters);
+    list.add(present_parameters);
     if (present_parameters)
-      builder.append(parameters);
+      list.add(parameters);
 
     boolean present_privileges = true && (isSetPrivileges());
-    builder.append(present_privileges);
+    list.add(present_privileges);
     if (present_privileges)
-      builder.append(privileges);
+      list.add(privileges);
 
     boolean present_ownerName = true && (isSetOwnerName());
-    builder.append(present_ownerName);
+    list.add(present_ownerName);
     if (present_ownerName)
-      builder.append(ownerName);
+      list.add(ownerName);
 
     boolean present_ownerType = true && (isSetOwnerType());
-    builder.append(present_ownerType);
+    list.add(present_ownerType);
     if (present_ownerType)
-      builder.append(ownerType.getValue());
+      list.add(ownerType.getValue());
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Database other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Database typedOther = (Database)other;
 
-    lastComparison = Boolean.valueOf(isSetName()).compareTo(typedOther.isSetName());
+    lastComparison = Boolean.valueOf(isSetName()).compareTo(other.isSetName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, typedOther.name);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.name, other.name);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDescription()).compareTo(typedOther.isSetDescription());
+    lastComparison = Boolean.valueOf(isSetDescription()).compareTo(other.isSetDescription());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDescription()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.description, typedOther.description);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.description, other.description);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetLocationUri()).compareTo(typedOther.isSetLocationUri());
+    lastComparison = Boolean.valueOf(isSetLocationUri()).compareTo(other.isSetLocationUri());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLocationUri()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.locationUri, typedOther.locationUri);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.locationUri, other.locationUri);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(typedOther.isSetParameters());
+    lastComparison = Boolean.valueOf(isSetParameters()).compareTo(other.isSetParameters());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParameters()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, typedOther.parameters);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parameters, other.parameters);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(typedOther.isSetPrivileges());
+    lastComparison = Boolean.valueOf(isSetPrivileges()).compareTo(other.isSetPrivileges());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPrivileges()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, typedOther.privileges);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.privileges, other.privileges);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(typedOther.isSetOwnerName());
+    lastComparison = Boolean.valueOf(isSetOwnerName()).compareTo(other.isSetOwnerName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwnerName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, typedOther.ownerName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerName, other.ownerName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOwnerType()).compareTo(typedOther.isSetOwnerType());
+    lastComparison = Boolean.valueOf(isSetOwnerType()).compareTo(other.isSetOwnerType());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOwnerType()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerType, typedOther.ownerType);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ownerType, other.ownerType);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -879,13 +872,13 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
               {
                 org.apache.thrift.protocol.TMap _map94 = iprot.readMapBegin();
                 struct.parameters = new HashMap<String,String>(2*_map94.size);
-                for (int _i95 = 0; _i95 < _map94.size; ++_i95)
+                String _key95;
+                String _val96;
+                for (int _i97 = 0; _i97 < _map94.size; ++_i97)
                 {
-                  String _key96; // required
-                  String _val97; // required
-                  _key96 = iprot.readString();
-                  _val97 = iprot.readString();
-                  struct.parameters.put(_key96, _val97);
+                  _key95 = iprot.readString();
+                  _val96 = iprot.readString();
+                  struct.parameters.put(_key95, _val96);
                 }
                 iprot.readMapEnd();
               }
@@ -913,7 +906,7 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
             break;
           case 7: // OWNER_TYPE
             if (schemeField.type == org.apache.thrift.protocol.TType.I32) {
-              struct.ownerType = PrincipalType.findByValue(iprot.readI32());
+              struct.ownerType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
               struct.setOwnerTypeIsSet(true);
             } else { 
               org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
@@ -1071,13 +1064,13 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
         {
           org.apache.thrift.protocol.TMap _map100 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.parameters = new HashMap<String,String>(2*_map100.size);
-          for (int _i101 = 0; _i101 < _map100.size; ++_i101)
+          String _key101;
+          String _val102;
+          for (int _i103 = 0; _i103 < _map100.size; ++_i103)
           {
-            String _key102; // required
-            String _val103; // required
-            _key102 = iprot.readString();
-            _val103 = iprot.readString();
-            struct.parameters.put(_key102, _val103);
+            _key101 = iprot.readString();
+            _val102 = iprot.readString();
+            struct.parameters.put(_key101, _val102);
           }
         }
         struct.setParametersIsSet(true);
@@ -1092,7 +1085,7 @@ public class Database implements org.apache.thrift.TBase<Database, Database._Fie
         struct.setOwnerNameIsSet(true);
       }
       if (incoming.get(6)) {
-        struct.ownerType = PrincipalType.findByValue(iprot.readI32());
+        struct.ownerType = org.apache.hadoop.hive.metastore.api.PrincipalType.findByValue(iprot.readI32());
         struct.setOwnerTypeIsSet(true);
       }
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Date.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Date.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Date.java
index 3e02db5..b04898a 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Date.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Date.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Date implements org.apache.thrift.TBase<Date, Date._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Date implements org.apache.thrift.TBase<Date, Date._Fields>, java.io.Serializable, Cloneable, Comparable<Date> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Date");
 
   private static final org.apache.thrift.protocol.TField DAYS_SINCE_EPOCH_FIELD_DESC = new org.apache.thrift.protocol.TField("daysSinceEpoch", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -227,30 +231,30 @@ public class Date implements org.apache.thrift.TBase<Date, Date._Fields>, java.i
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_daysSinceEpoch = true;
-    builder.append(present_daysSinceEpoch);
+    list.add(present_daysSinceEpoch);
     if (present_daysSinceEpoch)
-      builder.append(daysSinceEpoch);
+      list.add(daysSinceEpoch);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Date other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Date typedOther = (Date)other;
 
-    lastComparison = Boolean.valueOf(isSetDaysSinceEpoch()).compareTo(typedOther.isSetDaysSinceEpoch());
+    lastComparison = Boolean.valueOf(isSetDaysSinceEpoch()).compareTo(other.isSetDaysSinceEpoch());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDaysSinceEpoch()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.daysSinceEpoch, typedOther.daysSinceEpoch);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.daysSinceEpoch, other.daysSinceEpoch);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DateColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DateColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DateColumnStatsData.java
index e9a577d..73ed883 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DateColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DateColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DateColumnStatsData implements org.apache.thrift.TBase<DateColumnStatsData, DateColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DateColumnStatsData implements org.apache.thrift.TBase<DateColumnStatsData, DateColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<DateColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DateColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField LOW_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("lowValue", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -121,7 +125,7 @@ public class DateColumnStatsData implements org.apache.thrift.TBase<DateColumnSt
   private static final int __NUMNULLS_ISSET_ID = 0;
   private static final int __NUMDVS_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
+  private static final _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -398,75 +402,75 @@ public class DateColumnStatsData implements org.apache.thrift.TBase<DateColumnSt
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lowValue = true && (isSetLowValue());
-    builder.append(present_lowValue);
+    list.add(present_lowValue);
     if (present_lowValue)
-      builder.append(lowValue);
+      list.add(lowValue);
 
     boolean present_highValue = true && (isSetHighValue());
-    builder.append(present_highValue);
+    list.add(present_highValue);
     if (present_highValue)
-      builder.append(highValue);
+      list.add(highValue);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
     boolean present_numDVs = true;
-    builder.append(present_numDVs);
+    list.add(present_numDVs);
     if (present_numDVs)
-      builder.append(numDVs);
+      list.add(numDVs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DateColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DateColumnStatsData typedOther = (DateColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(typedOther.isSetLowValue());
+    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(other.isSetLowValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLowValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, typedOther.lowValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, other.lowValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(typedOther.isSetHighValue());
+    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(other.isSetHighValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHighValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, typedOther.highValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, other.highValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(typedOther.isSetNumDVs());
+    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(other.isSetNumDVs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumDVs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, typedOther.numDVs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, other.numDVs);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Decimal.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Decimal.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Decimal.java
index ed8bb18..57bcf84 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Decimal.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Decimal.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields>, java.io.Serializable, Cloneable, Comparable<Decimal> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("Decimal");
 
   private static final org.apache.thrift.protocol.TField UNSCALED_FIELD_DESC = new org.apache.thrift.protocol.TField("unscaled", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -129,7 +133,7 @@ public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields
     short scale)
   {
     this();
-    this.unscaled = unscaled;
+    this.unscaled = org.apache.thrift.TBaseHelper.copyBinary(unscaled);
     this.scale = scale;
     setScaleIsSet(true);
   }
@@ -141,7 +145,6 @@ public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetUnscaled()) {
       this.unscaled = org.apache.thrift.TBaseHelper.copyBinary(other.unscaled);
-;
     }
     this.scale = other.scale;
   }
@@ -163,15 +166,15 @@ public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields
   }
 
   public ByteBuffer bufferForUnscaled() {
-    return unscaled;
+    return org.apache.thrift.TBaseHelper.copyBinary(unscaled);
   }
 
   public void setUnscaled(byte[] unscaled) {
-    setUnscaled(unscaled == null ? (ByteBuffer)null : ByteBuffer.wrap(unscaled));
+    this.unscaled = unscaled == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(unscaled, unscaled.length));
   }
 
   public void setUnscaled(ByteBuffer unscaled) {
-    this.unscaled = unscaled;
+    this.unscaled = org.apache.thrift.TBaseHelper.copyBinary(unscaled);
   }
 
   public void unsetUnscaled() {
@@ -295,45 +298,45 @@ public class Decimal implements org.apache.thrift.TBase<Decimal, Decimal._Fields
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_unscaled = true && (isSetUnscaled());
-    builder.append(present_unscaled);
+    list.add(present_unscaled);
     if (present_unscaled)
-      builder.append(unscaled);
+      list.add(unscaled);
 
     boolean present_scale = true;
-    builder.append(present_scale);
+    list.add(present_scale);
     if (present_scale)
-      builder.append(scale);
+      list.add(scale);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(Decimal other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    Decimal typedOther = (Decimal)other;
 
-    lastComparison = Boolean.valueOf(isSetUnscaled()).compareTo(typedOther.isSetUnscaled());
+    lastComparison = Boolean.valueOf(isSetUnscaled()).compareTo(other.isSetUnscaled());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetUnscaled()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unscaled, typedOther.unscaled);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.unscaled, other.unscaled);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetScale()).compareTo(typedOther.isSetScale());
+    lastComparison = Boolean.valueOf(isSetScale()).compareTo(other.isSetScale());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetScale()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.scale, typedOther.scale);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.scale, other.scale);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DecimalColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DecimalColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DecimalColumnStatsData.java
index 951d479..1ed46ea 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DecimalColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DecimalColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DecimalColumnStatsData implements org.apache.thrift.TBase<DecimalColumnStatsData, DecimalColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DecimalColumnStatsData implements org.apache.thrift.TBase<DecimalColumnStatsData, DecimalColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<DecimalColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DecimalColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField LOW_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("lowValue", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -121,7 +125,7 @@ public class DecimalColumnStatsData implements org.apache.thrift.TBase<DecimalCo
   private static final int __NUMNULLS_ISSET_ID = 0;
   private static final int __NUMDVS_ISSET_ID = 1;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
+  private static final _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -398,75 +402,75 @@ public class DecimalColumnStatsData implements org.apache.thrift.TBase<DecimalCo
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lowValue = true && (isSetLowValue());
-    builder.append(present_lowValue);
+    list.add(present_lowValue);
     if (present_lowValue)
-      builder.append(lowValue);
+      list.add(lowValue);
 
     boolean present_highValue = true && (isSetHighValue());
-    builder.append(present_highValue);
+    list.add(present_highValue);
     if (present_highValue)
-      builder.append(highValue);
+      list.add(highValue);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
     boolean present_numDVs = true;
-    builder.append(present_numDVs);
+    list.add(present_numDVs);
     if (present_numDVs)
-      builder.append(numDVs);
+      list.add(numDVs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DecimalColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DecimalColumnStatsData typedOther = (DecimalColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(typedOther.isSetLowValue());
+    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(other.isSetLowValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLowValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, typedOther.lowValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, other.lowValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(typedOther.isSetHighValue());
+    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(other.isSetHighValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHighValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, typedOther.highValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, other.highValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(typedOther.isSetNumDVs());
+    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(other.isSetNumDVs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumDVs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, typedOther.numDVs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, other.numDVs);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DoubleColumnStatsData.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DoubleColumnStatsData.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DoubleColumnStatsData.java
index 4203fd8..8b4843f 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DoubleColumnStatsData.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DoubleColumnStatsData.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DoubleColumnStatsData implements org.apache.thrift.TBase<DoubleColumnStatsData, DoubleColumnStatsData._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DoubleColumnStatsData implements org.apache.thrift.TBase<DoubleColumnStatsData, DoubleColumnStatsData._Fields>, java.io.Serializable, Cloneable, Comparable<DoubleColumnStatsData> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DoubleColumnStatsData");
 
   private static final org.apache.thrift.protocol.TField LOW_VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("lowValue", org.apache.thrift.protocol.TType.DOUBLE, (short)1);
@@ -123,7 +127,7 @@ public class DoubleColumnStatsData implements org.apache.thrift.TBase<DoubleColu
   private static final int __NUMNULLS_ISSET_ID = 2;
   private static final int __NUMDVS_ISSET_ID = 3;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
+  private static final _Fields optionals[] = {_Fields.LOW_VALUE,_Fields.HIGH_VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -396,75 +400,75 @@ public class DoubleColumnStatsData implements org.apache.thrift.TBase<DoubleColu
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_lowValue = true && (isSetLowValue());
-    builder.append(present_lowValue);
+    list.add(present_lowValue);
     if (present_lowValue)
-      builder.append(lowValue);
+      list.add(lowValue);
 
     boolean present_highValue = true && (isSetHighValue());
-    builder.append(present_highValue);
+    list.add(present_highValue);
     if (present_highValue)
-      builder.append(highValue);
+      list.add(highValue);
 
     boolean present_numNulls = true;
-    builder.append(present_numNulls);
+    list.add(present_numNulls);
     if (present_numNulls)
-      builder.append(numNulls);
+      list.add(numNulls);
 
     boolean present_numDVs = true;
-    builder.append(present_numDVs);
+    list.add(present_numDVs);
     if (present_numDVs)
-      builder.append(numDVs);
+      list.add(numDVs);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DoubleColumnStatsData other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DoubleColumnStatsData typedOther = (DoubleColumnStatsData)other;
 
-    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(typedOther.isSetLowValue());
+    lastComparison = Boolean.valueOf(isSetLowValue()).compareTo(other.isSetLowValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetLowValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, typedOther.lowValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.lowValue, other.lowValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(typedOther.isSetHighValue());
+    lastComparison = Boolean.valueOf(isSetHighValue()).compareTo(other.isSetHighValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetHighValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, typedOther.highValue);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.highValue, other.highValue);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(typedOther.isSetNumNulls());
+    lastComparison = Boolean.valueOf(isSetNumNulls()).compareTo(other.isSetNumNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, typedOther.numNulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numNulls, other.numNulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(typedOther.isSetNumDVs());
+    lastComparison = Boolean.valueOf(isSetNumDVs()).compareTo(other.isSetNumDVs());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNumDVs()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, typedOther.numDVs);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numDVs, other.numDVs);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsExpr.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsExpr.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsExpr.java
index 59a66f3..e261d71 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsExpr.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsExpr.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartitionsExpr, DropPartitionsExpr._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartitionsExpr, DropPartitionsExpr._Fields>, java.io.Serializable, Cloneable, Comparable<DropPartitionsExpr> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DropPartitionsExpr");
 
   private static final org.apache.thrift.protocol.TField EXPR_FIELD_DESC = new org.apache.thrift.protocol.TField("expr", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -110,7 +114,7 @@ public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartition
   // isset id assignments
   private static final int __PARTARCHIVELEVEL_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.PART_ARCHIVE_LEVEL};
+  private static final _Fields optionals[] = {_Fields.PART_ARCHIVE_LEVEL};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -129,7 +133,7 @@ public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartition
     ByteBuffer expr)
   {
     this();
-    this.expr = expr;
+    this.expr = org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   /**
@@ -139,7 +143,6 @@ public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartition
     __isset_bitfield = other.__isset_bitfield;
     if (other.isSetExpr()) {
       this.expr = org.apache.thrift.TBaseHelper.copyBinary(other.expr);
-;
     }
     this.partArchiveLevel = other.partArchiveLevel;
   }
@@ -161,15 +164,15 @@ public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartition
   }
 
   public ByteBuffer bufferForExpr() {
-    return expr;
+    return org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   public void setExpr(byte[] expr) {
-    setExpr(expr == null ? (ByteBuffer)null : ByteBuffer.wrap(expr));
+    this.expr = expr == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(expr, expr.length));
   }
 
   public void setExpr(ByteBuffer expr) {
-    this.expr = expr;
+    this.expr = org.apache.thrift.TBaseHelper.copyBinary(expr);
   }
 
   public void unsetExpr() {
@@ -293,45 +296,45 @@ public class DropPartitionsExpr implements org.apache.thrift.TBase<DropPartition
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_expr = true && (isSetExpr());
-    builder.append(present_expr);
+    list.add(present_expr);
     if (present_expr)
-      builder.append(expr);
+      list.add(expr);
 
     boolean present_partArchiveLevel = true && (isSetPartArchiveLevel());
-    builder.append(present_partArchiveLevel);
+    list.add(present_partArchiveLevel);
     if (present_partArchiveLevel)
-      builder.append(partArchiveLevel);
+      list.add(partArchiveLevel);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DropPartitionsExpr other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DropPartitionsExpr typedOther = (DropPartitionsExpr)other;
 
-    lastComparison = Boolean.valueOf(isSetExpr()).compareTo(typedOther.isSetExpr());
+    lastComparison = Boolean.valueOf(isSetExpr()).compareTo(other.isSetExpr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetExpr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.expr, typedOther.expr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.expr, other.expr);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetPartArchiveLevel()).compareTo(typedOther.isSetPartArchiveLevel());
+    lastComparison = Boolean.valueOf(isSetPartArchiveLevel()).compareTo(other.isSetPartArchiveLevel());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartArchiveLevel()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partArchiveLevel, typedOther.partArchiveLevel);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partArchiveLevel, other.partArchiveLevel);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsRequest.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsRequest.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsRequest.java
index 1923f38..08c0aa0 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsRequest.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsRequest.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DropPartitionsRequest implements org.apache.thrift.TBase<DropPartitionsRequest, DropPartitionsRequest._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DropPartitionsRequest implements org.apache.thrift.TBase<DropPartitionsRequest, DropPartitionsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<DropPartitionsRequest> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DropPartitionsRequest");
 
   private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -143,7 +147,7 @@ public class DropPartitionsRequest implements org.apache.thrift.TBase<DropPartit
   private static final int __IGNOREPROTECTION_ISSET_ID = 2;
   private static final int __NEEDRESULT_ISSET_ID = 3;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.DELETE_DATA,_Fields.IF_EXISTS,_Fields.IGNORE_PROTECTION,_Fields.ENVIRONMENT_CONTEXT,_Fields.NEED_RESULT};
+  private static final _Fields optionals[] = {_Fields.DELETE_DATA,_Fields.IF_EXISTS,_Fields.IGNORE_PROTECTION,_Fields.ENVIRONMENT_CONTEXT,_Fields.NEED_RESULT};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -624,135 +628,135 @@ public class DropPartitionsRequest implements org.apache.thrift.TBase<DropPartit
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_dbName = true && (isSetDbName());
-    builder.append(present_dbName);
+    list.add(present_dbName);
     if (present_dbName)
-      builder.append(dbName);
+      list.add(dbName);
 
     boolean present_tblName = true && (isSetTblName());
-    builder.append(present_tblName);
+    list.add(present_tblName);
     if (present_tblName)
-      builder.append(tblName);
+      list.add(tblName);
 
     boolean present_parts = true && (isSetParts());
-    builder.append(present_parts);
+    list.add(present_parts);
     if (present_parts)
-      builder.append(parts);
+      list.add(parts);
 
     boolean present_deleteData = true && (isSetDeleteData());
-    builder.append(present_deleteData);
+    list.add(present_deleteData);
     if (present_deleteData)
-      builder.append(deleteData);
+      list.add(deleteData);
 
     boolean present_ifExists = true && (isSetIfExists());
-    builder.append(present_ifExists);
+    list.add(present_ifExists);
     if (present_ifExists)
-      builder.append(ifExists);
+      list.add(ifExists);
 
     boolean present_ignoreProtection = true && (isSetIgnoreProtection());
-    builder.append(present_ignoreProtection);
+    list.add(present_ignoreProtection);
     if (present_ignoreProtection)
-      builder.append(ignoreProtection);
+      list.add(ignoreProtection);
 
     boolean present_environmentContext = true && (isSetEnvironmentContext());
-    builder.append(present_environmentContext);
+    list.add(present_environmentContext);
     if (present_environmentContext)
-      builder.append(environmentContext);
+      list.add(environmentContext);
 
     boolean present_needResult = true && (isSetNeedResult());
-    builder.append(present_needResult);
+    list.add(present_needResult);
     if (present_needResult)
-      builder.append(needResult);
+      list.add(needResult);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DropPartitionsRequest other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DropPartitionsRequest typedOther = (DropPartitionsRequest)other;
 
-    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(typedOther.isSetDbName());
+    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDbName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, typedOther.dbName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(typedOther.isSetTblName());
+    lastComparison = Boolean.valueOf(isSetTblName()).compareTo(other.isSetTblName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTblName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, typedOther.tblName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tblName, other.tblName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetParts()).compareTo(typedOther.isSetParts());
+    lastComparison = Boolean.valueOf(isSetParts()).compareTo(other.isSetParts());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetParts()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parts, typedOther.parts);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.parts, other.parts);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetDeleteData()).compareTo(typedOther.isSetDeleteData());
+    lastComparison = Boolean.valueOf(isSetDeleteData()).compareTo(other.isSetDeleteData());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetDeleteData()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.deleteData, typedOther.deleteData);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.deleteData, other.deleteData);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetIfExists()).compareTo(typedOther.isSetIfExists());
+    lastComparison = Boolean.valueOf(isSetIfExists()).compareTo(other.isSetIfExists());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIfExists()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ifExists, typedOther.ifExists);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ifExists, other.ifExists);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetIgnoreProtection()).compareTo(typedOther.isSetIgnoreProtection());
+    lastComparison = Boolean.valueOf(isSetIgnoreProtection()).compareTo(other.isSetIgnoreProtection());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetIgnoreProtection()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ignoreProtection, typedOther.ignoreProtection);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ignoreProtection, other.ignoreProtection);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetEnvironmentContext()).compareTo(typedOther.isSetEnvironmentContext());
+    lastComparison = Boolean.valueOf(isSetEnvironmentContext()).compareTo(other.isSetEnvironmentContext());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetEnvironmentContext()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.environmentContext, typedOther.environmentContext);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.environmentContext, other.environmentContext);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNeedResult()).compareTo(typedOther.isSetNeedResult());
+    lastComparison = Boolean.valueOf(isSetNeedResult()).compareTo(other.isSetNeedResult());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNeedResult()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.needResult, typedOther.needResult);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.needResult, other.needResult);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java
index b7f69f2..bb3b34e 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.metastore.api;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartitionsResult, DropPartitionsResult._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartitionsResult, DropPartitionsResult._Fields>, java.io.Serializable, Cloneable, Comparable<DropPartitionsResult> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("DropPartitionsResult");
 
   private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -103,7 +107,7 @@ public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartiti
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.PARTITIONS};
+  private static final _Fields optionals[] = {_Fields.PARTITIONS};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -122,7 +126,7 @@ public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartiti
    */
   public DropPartitionsResult(DropPartitionsResult other) {
     if (other.isSetPartitions()) {
-      List<Partition> __this__partitions = new ArrayList<Partition>();
+      List<Partition> __this__partitions = new ArrayList<Partition>(other.partitions.size());
       for (Partition other_element : other.partitions) {
         __this__partitions.add(new Partition(other_element));
       }
@@ -239,30 +243,30 @@ public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartiti
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_partitions = true && (isSetPartitions());
-    builder.append(present_partitions);
+    list.add(present_partitions);
     if (present_partitions)
-      builder.append(partitions);
+      list.add(partitions);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(DropPartitionsResult other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    DropPartitionsResult typedOther = (DropPartitionsResult)other;
 
-    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(typedOther.isSetPartitions());
+    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetPartitions()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, typedOther.partitions);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -344,12 +348,12 @@ public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartiti
               {
                 org.apache.thrift.protocol.TList _list396 = iprot.readListBegin();
                 struct.partitions = new ArrayList<Partition>(_list396.size);
-                for (int _i397 = 0; _i397 < _list396.size; ++_i397)
+                Partition _elem397;
+                for (int _i398 = 0; _i398 < _list396.size; ++_i398)
                 {
-                  Partition _elem398; // optional
-                  _elem398 = new Partition();
-                  _elem398.read(iprot);
-                  struct.partitions.add(_elem398);
+                  _elem397 = new Partition();
+                  _elem397.read(iprot);
+                  struct.partitions.add(_elem397);
                 }
                 iprot.readListEnd();
               }
@@ -426,12 +430,12 @@ public class DropPartitionsResult implements org.apache.thrift.TBase<DropPartiti
         {
           org.apache.thrift.protocol.TList _list401 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
           struct.partitions = new ArrayList<Partition>(_list401.size);
-          for (int _i402 = 0; _i402 < _list401.size; ++_i402)
+          Partition _elem402;
+          for (int _i403 = 0; _i403 < _list401.size; ++_i403)
           {
-            Partition _elem403; // optional
-            _elem403 = new Partition();
-            _elem403.read(iprot);
-            struct.partitions.add(_elem403);
+            _elem402 = new Partition();
+            _elem402.read(iprot);
+            struct.partitions.add(_elem402);
           }
         }
         struct.setPartitionsIsSet(true);


[43/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
index 9c91650..9dae61c 100644
--- a/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
+++ b/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
@@ -1,5 +1,5 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
@@ -7,11 +7,14 @@
 #ifndef hive_metastore_TYPES_H
 #define hive_metastore_TYPES_H
 
+#include <iosfwd>
+
 #include <thrift/Thrift.h>
 #include <thrift/TApplicationException.h>
 #include <thrift/protocol/TProtocol.h>
 #include <thrift/transport/TTransport.h>
 
+#include <thrift/cxxfunctional.h>
 #include "fb303_types.h"
 
 
@@ -134,10 +137,226 @@ struct ResourceType {
 
 extern const std::map<int, const char*> _ResourceType_VALUES_TO_NAMES;
 
+class Version;
+
+class FieldSchema;
+
+class Type;
+
+class HiveObjectRef;
+
+class PrivilegeGrantInfo;
+
+class HiveObjectPrivilege;
+
+class PrivilegeBag;
+
+class PrincipalPrivilegeSet;
+
+class GrantRevokePrivilegeRequest;
+
+class GrantRevokePrivilegeResponse;
+
+class Role;
+
+class RolePrincipalGrant;
+
+class GetRoleGrantsForPrincipalRequest;
+
+class GetRoleGrantsForPrincipalResponse;
+
+class GetPrincipalsInRoleRequest;
+
+class GetPrincipalsInRoleResponse;
+
+class GrantRevokeRoleRequest;
+
+class GrantRevokeRoleResponse;
+
+class Database;
+
+class SerDeInfo;
+
+class Order;
+
+class SkewedInfo;
+
+class StorageDescriptor;
+
+class Table;
+
+class Partition;
+
+class PartitionWithoutSD;
+
+class PartitionSpecWithSharedSD;
+
+class PartitionListComposingSpec;
+
+class PartitionSpec;
+
+class Index;
+
+class BooleanColumnStatsData;
+
+class DoubleColumnStatsData;
+
+class LongColumnStatsData;
+
+class StringColumnStatsData;
+
+class BinaryColumnStatsData;
+
+class Decimal;
+
+class DecimalColumnStatsData;
+
+class Date;
+
+class DateColumnStatsData;
+
+class ColumnStatisticsData;
+
+class ColumnStatisticsObj;
+
+class ColumnStatisticsDesc;
+
+class ColumnStatistics;
+
+class AggrStats;
+
+class SetPartitionsStatsRequest;
+
+class Schema;
+
+class EnvironmentContext;
+
+class PartitionsByExprResult;
+
+class PartitionsByExprRequest;
+
+class TableStatsResult;
+
+class PartitionsStatsResult;
+
+class TableStatsRequest;
+
+class PartitionsStatsRequest;
+
+class AddPartitionsResult;
+
+class AddPartitionsRequest;
+
+class DropPartitionsResult;
+
+class DropPartitionsExpr;
+
+class RequestPartsSpec;
+
+class DropPartitionsRequest;
+
+class ResourceUri;
+
+class Function;
+
+class TxnInfo;
+
+class GetOpenTxnsInfoResponse;
+
+class GetOpenTxnsResponse;
+
+class OpenTxnRequest;
+
+class OpenTxnsResponse;
+
+class AbortTxnRequest;
+
+class CommitTxnRequest;
+
+class LockComponent;
+
+class LockRequest;
+
+class LockResponse;
+
+class CheckLockRequest;
+
+class UnlockRequest;
+
+class ShowLocksRequest;
+
+class ShowLocksResponseElement;
+
+class ShowLocksResponse;
+
+class HeartbeatRequest;
+
+class HeartbeatTxnRangeRequest;
+
+class HeartbeatTxnRangeResponse;
+
+class CompactionRequest;
+
+class ShowCompactRequest;
+
+class ShowCompactResponseElement;
+
+class ShowCompactResponse;
+
+class AddDynamicPartitions;
+
+class NotificationEventRequest;
+
+class NotificationEvent;
+
+class NotificationEventResponse;
+
+class CurrentNotificationEventId;
+
+class InsertEventRequestData;
+
+class FireEventRequestData;
+
+class FireEventRequest;
+
+class FireEventResponse;
+
+class MetaException;
+
+class UnknownTableException;
+
+class UnknownDBException;
+
+class AlreadyExistsException;
+
+class InvalidPartitionException;
+
+class UnknownPartitionException;
+
+class InvalidObjectException;
+
+class NoSuchObjectException;
+
+class IndexAlreadyExistsException;
+
+class InvalidOperationException;
+
+class ConfigValSecurityException;
+
+class InvalidInputException;
+
+class NoSuchTxnException;
+
+class TxnAbortedException;
+
+class TxnOpenException;
+
+class NoSuchLockException;
+
 typedef struct _Version__isset {
   _Version__isset() : version(false), comments(false) {}
-  bool version;
-  bool comments;
+  bool version :1;
+  bool comments :1;
 } _Version__isset;
 
 class Version {
@@ -146,23 +365,20 @@ class Version {
   static const char* ascii_fingerprint; // = "07A9615F837F7D0A952B595DD3020972";
   static const uint8_t binary_fingerprint[16]; // = {0x07,0xA9,0x61,0x5F,0x83,0x7F,0x7D,0x0A,0x95,0x2B,0x59,0x5D,0xD3,0x02,0x09,0x72};
 
+  Version(const Version&);
+  Version& operator=(const Version&);
   Version() : version(), comments() {
   }
 
-  virtual ~Version() throw() {}
-
+  virtual ~Version() throw();
   std::string version;
   std::string comments;
 
   _Version__isset __isset;
 
-  void __set_version(const std::string& val) {
-    version = val;
-  }
+  void __set_version(const std::string& val);
 
-  void __set_comments(const std::string& val) {
-    comments = val;
-  }
+  void __set_comments(const std::string& val);
 
   bool operator == (const Version & rhs) const
   {
@@ -181,15 +397,16 @@ class Version {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Version& obj);
 };
 
 void swap(Version &a, Version &b);
 
 typedef struct _FieldSchema__isset {
   _FieldSchema__isset() : name(false), type(false), comment(false) {}
-  bool name;
-  bool type;
-  bool comment;
+  bool name :1;
+  bool type :1;
+  bool comment :1;
 } _FieldSchema__isset;
 
 class FieldSchema {
@@ -198,28 +415,23 @@ class FieldSchema {
   static const char* ascii_fingerprint; // = "AB879940BD15B6B25691265F7384B271";
   static const uint8_t binary_fingerprint[16]; // = {0xAB,0x87,0x99,0x40,0xBD,0x15,0xB6,0xB2,0x56,0x91,0x26,0x5F,0x73,0x84,0xB2,0x71};
 
+  FieldSchema(const FieldSchema&);
+  FieldSchema& operator=(const FieldSchema&);
   FieldSchema() : name(), type(), comment() {
   }
 
-  virtual ~FieldSchema() throw() {}
-
+  virtual ~FieldSchema() throw();
   std::string name;
   std::string type;
   std::string comment;
 
   _FieldSchema__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
-  void __set_type(const std::string& val) {
-    type = val;
-  }
+  void __set_type(const std::string& val);
 
-  void __set_comment(const std::string& val) {
-    comment = val;
-  }
+  void __set_comment(const std::string& val);
 
   bool operator == (const FieldSchema & rhs) const
   {
@@ -240,16 +452,17 @@ class FieldSchema {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const FieldSchema& obj);
 };
 
 void swap(FieldSchema &a, FieldSchema &b);
 
 typedef struct _Type__isset {
   _Type__isset() : name(false), type1(false), type2(false), fields(false) {}
-  bool name;
-  bool type1;
-  bool type2;
-  bool fields;
+  bool name :1;
+  bool type1 :1;
+  bool type2 :1;
+  bool fields :1;
 } _Type__isset;
 
 class Type {
@@ -258,11 +471,12 @@ class Type {
   static const char* ascii_fingerprint; // = "20DF02DE523C27F7066C7BD4D9120842";
   static const uint8_t binary_fingerprint[16]; // = {0x20,0xDF,0x02,0xDE,0x52,0x3C,0x27,0xF7,0x06,0x6C,0x7B,0xD4,0xD9,0x12,0x08,0x42};
 
+  Type(const Type&);
+  Type& operator=(const Type&);
   Type() : name(), type1(), type2() {
   }
 
-  virtual ~Type() throw() {}
-
+  virtual ~Type() throw();
   std::string name;
   std::string type1;
   std::string type2;
@@ -270,24 +484,13 @@ class Type {
 
   _Type__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
-  void __set_type1(const std::string& val) {
-    type1 = val;
-    __isset.type1 = true;
-  }
+  void __set_type1(const std::string& val);
 
-  void __set_type2(const std::string& val) {
-    type2 = val;
-    __isset.type2 = true;
-  }
+  void __set_type2(const std::string& val);
 
-  void __set_fields(const std::vector<FieldSchema> & val) {
-    fields = val;
-    __isset.fields = true;
-  }
+  void __set_fields(const std::vector<FieldSchema> & val);
 
   bool operator == (const Type & rhs) const
   {
@@ -316,17 +519,18 @@ class Type {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Type& obj);
 };
 
 void swap(Type &a, Type &b);
 
 typedef struct _HiveObjectRef__isset {
   _HiveObjectRef__isset() : objectType(false), dbName(false), objectName(false), partValues(false), columnName(false) {}
-  bool objectType;
-  bool dbName;
-  bool objectName;
-  bool partValues;
-  bool columnName;
+  bool objectType :1;
+  bool dbName :1;
+  bool objectName :1;
+  bool partValues :1;
+  bool columnName :1;
 } _HiveObjectRef__isset;
 
 class HiveObjectRef {
@@ -335,11 +539,12 @@ class HiveObjectRef {
   static const char* ascii_fingerprint; // = "205CD8311CF3AA9EC161BAEF8D7C933C";
   static const uint8_t binary_fingerprint[16]; // = {0x20,0x5C,0xD8,0x31,0x1C,0xF3,0xAA,0x9E,0xC1,0x61,0xBA,0xEF,0x8D,0x7C,0x93,0x3C};
 
+  HiveObjectRef(const HiveObjectRef&);
+  HiveObjectRef& operator=(const HiveObjectRef&);
   HiveObjectRef() : objectType((HiveObjectType::type)0), dbName(), objectName(), columnName() {
   }
 
-  virtual ~HiveObjectRef() throw() {}
-
+  virtual ~HiveObjectRef() throw();
   HiveObjectType::type objectType;
   std::string dbName;
   std::string objectName;
@@ -348,25 +553,15 @@ class HiveObjectRef {
 
   _HiveObjectRef__isset __isset;
 
-  void __set_objectType(const HiveObjectType::type val) {
-    objectType = val;
-  }
+  void __set_objectType(const HiveObjectType::type val);
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_objectName(const std::string& val) {
-    objectName = val;
-  }
+  void __set_objectName(const std::string& val);
 
-  void __set_partValues(const std::vector<std::string> & val) {
-    partValues = val;
-  }
+  void __set_partValues(const std::vector<std::string> & val);
 
-  void __set_columnName(const std::string& val) {
-    columnName = val;
-  }
+  void __set_columnName(const std::string& val);
 
   bool operator == (const HiveObjectRef & rhs) const
   {
@@ -391,17 +586,18 @@ class HiveObjectRef {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const HiveObjectRef& obj);
 };
 
 void swap(HiveObjectRef &a, HiveObjectRef &b);
 
 typedef struct _PrivilegeGrantInfo__isset {
   _PrivilegeGrantInfo__isset() : privilege(false), createTime(false), grantor(false), grantorType(false), grantOption(false) {}
-  bool privilege;
-  bool createTime;
-  bool grantor;
-  bool grantorType;
-  bool grantOption;
+  bool privilege :1;
+  bool createTime :1;
+  bool grantor :1;
+  bool grantorType :1;
+  bool grantOption :1;
 } _PrivilegeGrantInfo__isset;
 
 class PrivilegeGrantInfo {
@@ -410,11 +606,12 @@ class PrivilegeGrantInfo {
   static const char* ascii_fingerprint; // = "A58923AF7294BE492D6F90E07E8CEE1F";
   static const uint8_t binary_fingerprint[16]; // = {0xA5,0x89,0x23,0xAF,0x72,0x94,0xBE,0x49,0x2D,0x6F,0x90,0xE0,0x7E,0x8C,0xEE,0x1F};
 
+  PrivilegeGrantInfo(const PrivilegeGrantInfo&);
+  PrivilegeGrantInfo& operator=(const PrivilegeGrantInfo&);
   PrivilegeGrantInfo() : privilege(), createTime(0), grantor(), grantorType((PrincipalType::type)0), grantOption(0) {
   }
 
-  virtual ~PrivilegeGrantInfo() throw() {}
-
+  virtual ~PrivilegeGrantInfo() throw();
   std::string privilege;
   int32_t createTime;
   std::string grantor;
@@ -423,25 +620,15 @@ class PrivilegeGrantInfo {
 
   _PrivilegeGrantInfo__isset __isset;
 
-  void __set_privilege(const std::string& val) {
-    privilege = val;
-  }
+  void __set_privilege(const std::string& val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_grantor(const std::string& val) {
-    grantor = val;
-  }
+  void __set_grantor(const std::string& val);
 
-  void __set_grantorType(const PrincipalType::type val) {
-    grantorType = val;
-  }
+  void __set_grantorType(const PrincipalType::type val);
 
-  void __set_grantOption(const bool val) {
-    grantOption = val;
-  }
+  void __set_grantOption(const bool val);
 
   bool operator == (const PrivilegeGrantInfo & rhs) const
   {
@@ -466,16 +653,17 @@ class PrivilegeGrantInfo {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PrivilegeGrantInfo& obj);
 };
 
 void swap(PrivilegeGrantInfo &a, PrivilegeGrantInfo &b);
 
 typedef struct _HiveObjectPrivilege__isset {
   _HiveObjectPrivilege__isset() : hiveObject(false), principalName(false), principalType(false), grantInfo(false) {}
-  bool hiveObject;
-  bool principalName;
-  bool principalType;
-  bool grantInfo;
+  bool hiveObject :1;
+  bool principalName :1;
+  bool principalType :1;
+  bool grantInfo :1;
 } _HiveObjectPrivilege__isset;
 
 class HiveObjectPrivilege {
@@ -484,11 +672,12 @@ class HiveObjectPrivilege {
   static const char* ascii_fingerprint; // = "83D71969B23BD853E29DBA9D43B29AF8";
   static const uint8_t binary_fingerprint[16]; // = {0x83,0xD7,0x19,0x69,0xB2,0x3B,0xD8,0x53,0xE2,0x9D,0xBA,0x9D,0x43,0xB2,0x9A,0xF8};
 
+  HiveObjectPrivilege(const HiveObjectPrivilege&);
+  HiveObjectPrivilege& operator=(const HiveObjectPrivilege&);
   HiveObjectPrivilege() : principalName(), principalType((PrincipalType::type)0) {
   }
 
-  virtual ~HiveObjectPrivilege() throw() {}
-
+  virtual ~HiveObjectPrivilege() throw();
   HiveObjectRef hiveObject;
   std::string principalName;
   PrincipalType::type principalType;
@@ -496,21 +685,13 @@ class HiveObjectPrivilege {
 
   _HiveObjectPrivilege__isset __isset;
 
-  void __set_hiveObject(const HiveObjectRef& val) {
-    hiveObject = val;
-  }
+  void __set_hiveObject(const HiveObjectRef& val);
 
-  void __set_principalName(const std::string& val) {
-    principalName = val;
-  }
+  void __set_principalName(const std::string& val);
 
-  void __set_principalType(const PrincipalType::type val) {
-    principalType = val;
-  }
+  void __set_principalType(const PrincipalType::type val);
 
-  void __set_grantInfo(const PrivilegeGrantInfo& val) {
-    grantInfo = val;
-  }
+  void __set_grantInfo(const PrivilegeGrantInfo& val);
 
   bool operator == (const HiveObjectPrivilege & rhs) const
   {
@@ -533,13 +714,14 @@ class HiveObjectPrivilege {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const HiveObjectPrivilege& obj);
 };
 
 void swap(HiveObjectPrivilege &a, HiveObjectPrivilege &b);
 
 typedef struct _PrivilegeBag__isset {
   _PrivilegeBag__isset() : privileges(false) {}
-  bool privileges;
+  bool privileges :1;
 } _PrivilegeBag__isset;
 
 class PrivilegeBag {
@@ -548,18 +730,17 @@ class PrivilegeBag {
   static const char* ascii_fingerprint; // = "BB89E4701B7B709B046A74C90B1147F2";
   static const uint8_t binary_fingerprint[16]; // = {0xBB,0x89,0xE4,0x70,0x1B,0x7B,0x70,0x9B,0x04,0x6A,0x74,0xC9,0x0B,0x11,0x47,0xF2};
 
+  PrivilegeBag(const PrivilegeBag&);
+  PrivilegeBag& operator=(const PrivilegeBag&);
   PrivilegeBag() {
   }
 
-  virtual ~PrivilegeBag() throw() {}
-
+  virtual ~PrivilegeBag() throw();
   std::vector<HiveObjectPrivilege>  privileges;
 
   _PrivilegeBag__isset __isset;
 
-  void __set_privileges(const std::vector<HiveObjectPrivilege> & val) {
-    privileges = val;
-  }
+  void __set_privileges(const std::vector<HiveObjectPrivilege> & val);
 
   bool operator == (const PrivilegeBag & rhs) const
   {
@@ -576,15 +757,16 @@ class PrivilegeBag {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PrivilegeBag& obj);
 };
 
 void swap(PrivilegeBag &a, PrivilegeBag &b);
 
 typedef struct _PrincipalPrivilegeSet__isset {
   _PrincipalPrivilegeSet__isset() : userPrivileges(false), groupPrivileges(false), rolePrivileges(false) {}
-  bool userPrivileges;
-  bool groupPrivileges;
-  bool rolePrivileges;
+  bool userPrivileges :1;
+  bool groupPrivileges :1;
+  bool rolePrivileges :1;
 } _PrincipalPrivilegeSet__isset;
 
 class PrincipalPrivilegeSet {
@@ -593,28 +775,23 @@ class PrincipalPrivilegeSet {
   static const char* ascii_fingerprint; // = "08F75D2533906EA87BE34EA640856683";
   static const uint8_t binary_fingerprint[16]; // = {0x08,0xF7,0x5D,0x25,0x33,0x90,0x6E,0xA8,0x7B,0xE3,0x4E,0xA6,0x40,0x85,0x66,0x83};
 
+  PrincipalPrivilegeSet(const PrincipalPrivilegeSet&);
+  PrincipalPrivilegeSet& operator=(const PrincipalPrivilegeSet&);
   PrincipalPrivilegeSet() {
   }
 
-  virtual ~PrincipalPrivilegeSet() throw() {}
-
+  virtual ~PrincipalPrivilegeSet() throw();
   std::map<std::string, std::vector<PrivilegeGrantInfo> >  userPrivileges;
   std::map<std::string, std::vector<PrivilegeGrantInfo> >  groupPrivileges;
   std::map<std::string, std::vector<PrivilegeGrantInfo> >  rolePrivileges;
 
   _PrincipalPrivilegeSet__isset __isset;
 
-  void __set_userPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
-    userPrivileges = val;
-  }
+  void __set_userPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val);
 
-  void __set_groupPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
-    groupPrivileges = val;
-  }
+  void __set_groupPrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val);
 
-  void __set_rolePrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val) {
-    rolePrivileges = val;
-  }
+  void __set_rolePrivileges(const std::map<std::string, std::vector<PrivilegeGrantInfo> > & val);
 
   bool operator == (const PrincipalPrivilegeSet & rhs) const
   {
@@ -635,15 +812,16 @@ class PrincipalPrivilegeSet {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PrincipalPrivilegeSet& obj);
 };
 
 void swap(PrincipalPrivilegeSet &a, PrincipalPrivilegeSet &b);
 
 typedef struct _GrantRevokePrivilegeRequest__isset {
   _GrantRevokePrivilegeRequest__isset() : requestType(false), privileges(false), revokeGrantOption(false) {}
-  bool requestType;
-  bool privileges;
-  bool revokeGrantOption;
+  bool requestType :1;
+  bool privileges :1;
+  bool revokeGrantOption :1;
 } _GrantRevokePrivilegeRequest__isset;
 
 class GrantRevokePrivilegeRequest {
@@ -652,29 +830,23 @@ class GrantRevokePrivilegeRequest {
   static const char* ascii_fingerprint; // = "DF474A3CB526AD40DC0F2C3702F7AA2C";
   static const uint8_t binary_fingerprint[16]; // = {0xDF,0x47,0x4A,0x3C,0xB5,0x26,0xAD,0x40,0xDC,0x0F,0x2C,0x37,0x02,0xF7,0xAA,0x2C};
 
+  GrantRevokePrivilegeRequest(const GrantRevokePrivilegeRequest&);
+  GrantRevokePrivilegeRequest& operator=(const GrantRevokePrivilegeRequest&);
   GrantRevokePrivilegeRequest() : requestType((GrantRevokeType::type)0), revokeGrantOption(0) {
   }
 
-  virtual ~GrantRevokePrivilegeRequest() throw() {}
-
+  virtual ~GrantRevokePrivilegeRequest() throw();
   GrantRevokeType::type requestType;
   PrivilegeBag privileges;
   bool revokeGrantOption;
 
   _GrantRevokePrivilegeRequest__isset __isset;
 
-  void __set_requestType(const GrantRevokeType::type val) {
-    requestType = val;
-  }
+  void __set_requestType(const GrantRevokeType::type val);
 
-  void __set_privileges(const PrivilegeBag& val) {
-    privileges = val;
-  }
+  void __set_privileges(const PrivilegeBag& val);
 
-  void __set_revokeGrantOption(const bool val) {
-    revokeGrantOption = val;
-    __isset.revokeGrantOption = true;
-  }
+  void __set_revokeGrantOption(const bool val);
 
   bool operator == (const GrantRevokePrivilegeRequest & rhs) const
   {
@@ -697,13 +869,14 @@ class GrantRevokePrivilegeRequest {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GrantRevokePrivilegeRequest& obj);
 };
 
 void swap(GrantRevokePrivilegeRequest &a, GrantRevokePrivilegeRequest &b);
 
 typedef struct _GrantRevokePrivilegeResponse__isset {
   _GrantRevokePrivilegeResponse__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _GrantRevokePrivilegeResponse__isset;
 
 class GrantRevokePrivilegeResponse {
@@ -712,19 +885,17 @@ class GrantRevokePrivilegeResponse {
   static const char* ascii_fingerprint; // = "BF054652DEF86253C2BEE7D947F167DD";
   static const uint8_t binary_fingerprint[16]; // = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
+  GrantRevokePrivilegeResponse(const GrantRevokePrivilegeResponse&);
+  GrantRevokePrivilegeResponse& operator=(const GrantRevokePrivilegeResponse&);
   GrantRevokePrivilegeResponse() : success(0) {
   }
 
-  virtual ~GrantRevokePrivilegeResponse() throw() {}
-
+  virtual ~GrantRevokePrivilegeResponse() throw();
   bool success;
 
   _GrantRevokePrivilegeResponse__isset __isset;
 
-  void __set_success(const bool val) {
-    success = val;
-    __isset.success = true;
-  }
+  void __set_success(const bool val);
 
   bool operator == (const GrantRevokePrivilegeResponse & rhs) const
   {
@@ -743,15 +914,16 @@ class GrantRevokePrivilegeResponse {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GrantRevokePrivilegeResponse& obj);
 };
 
 void swap(GrantRevokePrivilegeResponse &a, GrantRevokePrivilegeResponse &b);
 
 typedef struct _Role__isset {
   _Role__isset() : roleName(false), createTime(false), ownerName(false) {}
-  bool roleName;
-  bool createTime;
-  bool ownerName;
+  bool roleName :1;
+  bool createTime :1;
+  bool ownerName :1;
 } _Role__isset;
 
 class Role {
@@ -760,28 +932,23 @@ class Role {
   static const char* ascii_fingerprint; // = "70563A0628F75DF9555F4D24690B1E26";
   static const uint8_t binary_fingerprint[16]; // = {0x70,0x56,0x3A,0x06,0x28,0xF7,0x5D,0xF9,0x55,0x5F,0x4D,0x24,0x69,0x0B,0x1E,0x26};
 
+  Role(const Role&);
+  Role& operator=(const Role&);
   Role() : roleName(), createTime(0), ownerName() {
   }
 
-  virtual ~Role() throw() {}
-
+  virtual ~Role() throw();
   std::string roleName;
   int32_t createTime;
   std::string ownerName;
 
   _Role__isset __isset;
 
-  void __set_roleName(const std::string& val) {
-    roleName = val;
-  }
+  void __set_roleName(const std::string& val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_ownerName(const std::string& val) {
-    ownerName = val;
-  }
+  void __set_ownerName(const std::string& val);
 
   bool operator == (const Role & rhs) const
   {
@@ -802,19 +969,20 @@ class Role {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Role& obj);
 };
 
 void swap(Role &a, Role &b);
 
 typedef struct _RolePrincipalGrant__isset {
   _RolePrincipalGrant__isset() : roleName(false), principalName(false), principalType(false), grantOption(false), grantTime(false), grantorName(false), grantorPrincipalType(false) {}
-  bool roleName;
-  bool principalName;
-  bool principalType;
-  bool grantOption;
-  bool grantTime;
-  bool grantorName;
-  bool grantorPrincipalType;
+  bool roleName :1;
+  bool principalName :1;
+  bool principalType :1;
+  bool grantOption :1;
+  bool grantTime :1;
+  bool grantorName :1;
+  bool grantorPrincipalType :1;
 } _RolePrincipalGrant__isset;
 
 class RolePrincipalGrant {
@@ -823,11 +991,12 @@ class RolePrincipalGrant {
   static const char* ascii_fingerprint; // = "899BA3F6214DD1B79D27206BA857C772";
   static const uint8_t binary_fingerprint[16]; // = {0x89,0x9B,0xA3,0xF6,0x21,0x4D,0xD1,0xB7,0x9D,0x27,0x20,0x6B,0xA8,0x57,0xC7,0x72};
 
+  RolePrincipalGrant(const RolePrincipalGrant&);
+  RolePrincipalGrant& operator=(const RolePrincipalGrant&);
   RolePrincipalGrant() : roleName(), principalName(), principalType((PrincipalType::type)0), grantOption(0), grantTime(0), grantorName(), grantorPrincipalType((PrincipalType::type)0) {
   }
 
-  virtual ~RolePrincipalGrant() throw() {}
-
+  virtual ~RolePrincipalGrant() throw();
   std::string roleName;
   std::string principalName;
   PrincipalType::type principalType;
@@ -838,33 +1007,19 @@ class RolePrincipalGrant {
 
   _RolePrincipalGrant__isset __isset;
 
-  void __set_roleName(const std::string& val) {
-    roleName = val;
-  }
+  void __set_roleName(const std::string& val);
 
-  void __set_principalName(const std::string& val) {
-    principalName = val;
-  }
+  void __set_principalName(const std::string& val);
 
-  void __set_principalType(const PrincipalType::type val) {
-    principalType = val;
-  }
+  void __set_principalType(const PrincipalType::type val);
 
-  void __set_grantOption(const bool val) {
-    grantOption = val;
-  }
+  void __set_grantOption(const bool val);
 
-  void __set_grantTime(const int32_t val) {
-    grantTime = val;
-  }
+  void __set_grantTime(const int32_t val);
 
-  void __set_grantorName(const std::string& val) {
-    grantorName = val;
-  }
+  void __set_grantorName(const std::string& val);
 
-  void __set_grantorPrincipalType(const PrincipalType::type val) {
-    grantorPrincipalType = val;
-  }
+  void __set_grantorPrincipalType(const PrincipalType::type val);
 
   bool operator == (const RolePrincipalGrant & rhs) const
   {
@@ -893,6 +1048,7 @@ class RolePrincipalGrant {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const RolePrincipalGrant& obj);
 };
 
 void swap(RolePrincipalGrant &a, RolePrincipalGrant &b);
@@ -904,21 +1060,18 @@ class GetRoleGrantsForPrincipalRequest {
   static const char* ascii_fingerprint; // = "D6FD826D949221396F4FFC3ECCD3D192";
   static const uint8_t binary_fingerprint[16]; // = {0xD6,0xFD,0x82,0x6D,0x94,0x92,0x21,0x39,0x6F,0x4F,0xFC,0x3E,0xCC,0xD3,0xD1,0x92};
 
+  GetRoleGrantsForPrincipalRequest(const GetRoleGrantsForPrincipalRequest&);
+  GetRoleGrantsForPrincipalRequest& operator=(const GetRoleGrantsForPrincipalRequest&);
   GetRoleGrantsForPrincipalRequest() : principal_name(), principal_type((PrincipalType::type)0) {
   }
 
-  virtual ~GetRoleGrantsForPrincipalRequest() throw() {}
-
+  virtual ~GetRoleGrantsForPrincipalRequest() throw();
   std::string principal_name;
   PrincipalType::type principal_type;
 
-  void __set_principal_name(const std::string& val) {
-    principal_name = val;
-  }
+  void __set_principal_name(const std::string& val);
 
-  void __set_principal_type(const PrincipalType::type val) {
-    principal_type = val;
-  }
+  void __set_principal_type(const PrincipalType::type val);
 
   bool operator == (const GetRoleGrantsForPrincipalRequest & rhs) const
   {
@@ -937,6 +1090,7 @@ class GetRoleGrantsForPrincipalRequest {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GetRoleGrantsForPrincipalRequest& obj);
 };
 
 void swap(GetRoleGrantsForPrincipalRequest &a, GetRoleGrantsForPrincipalRequest &b);
@@ -948,16 +1102,15 @@ class GetRoleGrantsForPrincipalResponse {
   static const char* ascii_fingerprint; // = "5926B4B3541A62E17663820C7E3BE690";
   static const uint8_t binary_fingerprint[16]; // = {0x59,0x26,0xB4,0xB3,0x54,0x1A,0x62,0xE1,0x76,0x63,0x82,0x0C,0x7E,0x3B,0xE6,0x90};
 
+  GetRoleGrantsForPrincipalResponse(const GetRoleGrantsForPrincipalResponse&);
+  GetRoleGrantsForPrincipalResponse& operator=(const GetRoleGrantsForPrincipalResponse&);
   GetRoleGrantsForPrincipalResponse() {
   }
 
-  virtual ~GetRoleGrantsForPrincipalResponse() throw() {}
-
+  virtual ~GetRoleGrantsForPrincipalResponse() throw();
   std::vector<RolePrincipalGrant>  principalGrants;
 
-  void __set_principalGrants(const std::vector<RolePrincipalGrant> & val) {
-    principalGrants = val;
-  }
+  void __set_principalGrants(const std::vector<RolePrincipalGrant> & val);
 
   bool operator == (const GetRoleGrantsForPrincipalResponse & rhs) const
   {
@@ -974,6 +1127,7 @@ class GetRoleGrantsForPrincipalResponse {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GetRoleGrantsForPrincipalResponse& obj);
 };
 
 void swap(GetRoleGrantsForPrincipalResponse &a, GetRoleGrantsForPrincipalResponse &b);
@@ -985,16 +1139,15 @@ class GetPrincipalsInRoleRequest {
   static const char* ascii_fingerprint; // = "EFB929595D312AC8F305D5A794CFEDA1";
   static const uint8_t binary_fingerprint[16]; // = {0xEF,0xB9,0x29,0x59,0x5D,0x31,0x2A,0xC8,0xF3,0x05,0xD5,0xA7,0x94,0xCF,0xED,0xA1};
 
+  GetPrincipalsInRoleRequest(const GetPrincipalsInRoleRequest&);
+  GetPrincipalsInRoleRequest& operator=(const GetPrincipalsInRoleRequest&);
   GetPrincipalsInRoleRequest() : roleName() {
   }
 
-  virtual ~GetPrincipalsInRoleRequest() throw() {}
-
+  virtual ~GetPrincipalsInRoleRequest() throw();
   std::string roleName;
 
-  void __set_roleName(const std::string& val) {
-    roleName = val;
-  }
+  void __set_roleName(const std::string& val);
 
   bool operator == (const GetPrincipalsInRoleRequest & rhs) const
   {
@@ -1011,6 +1164,7 @@ class GetPrincipalsInRoleRequest {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GetPrincipalsInRoleRequest& obj);
 };
 
 void swap(GetPrincipalsInRoleRequest &a, GetPrincipalsInRoleRequest &b);
@@ -1022,16 +1176,15 @@ class GetPrincipalsInRoleResponse {
   static const char* ascii_fingerprint; // = "5926B4B3541A62E17663820C7E3BE690";
   static const uint8_t binary_fingerprint[16]; // = {0x59,0x26,0xB4,0xB3,0x54,0x1A,0x62,0xE1,0x76,0x63,0x82,0x0C,0x7E,0x3B,0xE6,0x90};
 
+  GetPrincipalsInRoleResponse(const GetPrincipalsInRoleResponse&);
+  GetPrincipalsInRoleResponse& operator=(const GetPrincipalsInRoleResponse&);
   GetPrincipalsInRoleResponse() {
   }
 
-  virtual ~GetPrincipalsInRoleResponse() throw() {}
-
+  virtual ~GetPrincipalsInRoleResponse() throw();
   std::vector<RolePrincipalGrant>  principalGrants;
 
-  void __set_principalGrants(const std::vector<RolePrincipalGrant> & val) {
-    principalGrants = val;
-  }
+  void __set_principalGrants(const std::vector<RolePrincipalGrant> & val);
 
   bool operator == (const GetPrincipalsInRoleResponse & rhs) const
   {
@@ -1048,19 +1201,20 @@ class GetPrincipalsInRoleResponse {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GetPrincipalsInRoleResponse& obj);
 };
 
 void swap(GetPrincipalsInRoleResponse &a, GetPrincipalsInRoleResponse &b);
 
 typedef struct _GrantRevokeRoleRequest__isset {
   _GrantRevokeRoleRequest__isset() : requestType(false), roleName(false), principalName(false), principalType(false), grantor(false), grantorType(false), grantOption(false) {}
-  bool requestType;
-  bool roleName;
-  bool principalName;
-  bool principalType;
-  bool grantor;
-  bool grantorType;
-  bool grantOption;
+  bool requestType :1;
+  bool roleName :1;
+  bool principalName :1;
+  bool principalType :1;
+  bool grantor :1;
+  bool grantorType :1;
+  bool grantOption :1;
 } _GrantRevokeRoleRequest__isset;
 
 class GrantRevokeRoleRequest {
@@ -1069,11 +1223,12 @@ class GrantRevokeRoleRequest {
   static const char* ascii_fingerprint; // = "907DEA796F2BA7AF76DC2566E75FAEE7";
   static const uint8_t binary_fingerprint[16]; // = {0x90,0x7D,0xEA,0x79,0x6F,0x2B,0xA7,0xAF,0x76,0xDC,0x25,0x66,0xE7,0x5F,0xAE,0xE7};
 
+  GrantRevokeRoleRequest(const GrantRevokeRoleRequest&);
+  GrantRevokeRoleRequest& operator=(const GrantRevokeRoleRequest&);
   GrantRevokeRoleRequest() : requestType((GrantRevokeType::type)0), roleName(), principalName(), principalType((PrincipalType::type)0), grantor(), grantorType((PrincipalType::type)0), grantOption(0) {
   }
 
-  virtual ~GrantRevokeRoleRequest() throw() {}
-
+  virtual ~GrantRevokeRoleRequest() throw();
   GrantRevokeType::type requestType;
   std::string roleName;
   std::string principalName;
@@ -1084,36 +1239,19 @@ class GrantRevokeRoleRequest {
 
   _GrantRevokeRoleRequest__isset __isset;
 
-  void __set_requestType(const GrantRevokeType::type val) {
-    requestType = val;
-  }
+  void __set_requestType(const GrantRevokeType::type val);
 
-  void __set_roleName(const std::string& val) {
-    roleName = val;
-  }
+  void __set_roleName(const std::string& val);
 
-  void __set_principalName(const std::string& val) {
-    principalName = val;
-  }
+  void __set_principalName(const std::string& val);
 
-  void __set_principalType(const PrincipalType::type val) {
-    principalType = val;
-  }
+  void __set_principalType(const PrincipalType::type val);
 
-  void __set_grantor(const std::string& val) {
-    grantor = val;
-    __isset.grantor = true;
-  }
+  void __set_grantor(const std::string& val);
 
-  void __set_grantorType(const PrincipalType::type val) {
-    grantorType = val;
-    __isset.grantorType = true;
-  }
+  void __set_grantorType(const PrincipalType::type val);
 
-  void __set_grantOption(const bool val) {
-    grantOption = val;
-    __isset.grantOption = true;
-  }
+  void __set_grantOption(const bool val);
 
   bool operator == (const GrantRevokeRoleRequest & rhs) const
   {
@@ -1148,13 +1286,14 @@ class GrantRevokeRoleRequest {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GrantRevokeRoleRequest& obj);
 };
 
 void swap(GrantRevokeRoleRequest &a, GrantRevokeRoleRequest &b);
 
 typedef struct _GrantRevokeRoleResponse__isset {
   _GrantRevokeRoleResponse__isset() : success(false) {}
-  bool success;
+  bool success :1;
 } _GrantRevokeRoleResponse__isset;
 
 class GrantRevokeRoleResponse {
@@ -1163,19 +1302,17 @@ class GrantRevokeRoleResponse {
   static const char* ascii_fingerprint; // = "BF054652DEF86253C2BEE7D947F167DD";
   static const uint8_t binary_fingerprint[16]; // = {0xBF,0x05,0x46,0x52,0xDE,0xF8,0x62,0x53,0xC2,0xBE,0xE7,0xD9,0x47,0xF1,0x67,0xDD};
 
+  GrantRevokeRoleResponse(const GrantRevokeRoleResponse&);
+  GrantRevokeRoleResponse& operator=(const GrantRevokeRoleResponse&);
   GrantRevokeRoleResponse() : success(0) {
   }
 
-  virtual ~GrantRevokeRoleResponse() throw() {}
-
+  virtual ~GrantRevokeRoleResponse() throw();
   bool success;
 
   _GrantRevokeRoleResponse__isset __isset;
 
-  void __set_success(const bool val) {
-    success = val;
-    __isset.success = true;
-  }
+  void __set_success(const bool val);
 
   bool operator == (const GrantRevokeRoleResponse & rhs) const
   {
@@ -1194,19 +1331,20 @@ class GrantRevokeRoleResponse {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const GrantRevokeRoleResponse& obj);
 };
 
 void swap(GrantRevokeRoleResponse &a, GrantRevokeRoleResponse &b);
 
 typedef struct _Database__isset {
   _Database__isset() : name(false), description(false), locationUri(false), parameters(false), privileges(false), ownerName(false), ownerType(false) {}
-  bool name;
-  bool description;
-  bool locationUri;
-  bool parameters;
-  bool privileges;
-  bool ownerName;
-  bool ownerType;
+  bool name :1;
+  bool description :1;
+  bool locationUri :1;
+  bool parameters :1;
+  bool privileges :1;
+  bool ownerName :1;
+  bool ownerType :1;
 } _Database__isset;
 
 class Database {
@@ -1215,11 +1353,12 @@ class Database {
   static const char* ascii_fingerprint; // = "553495CAE243A1C583D5C3DD990AED53";
   static const uint8_t binary_fingerprint[16]; // = {0x55,0x34,0x95,0xCA,0xE2,0x43,0xA1,0xC5,0x83,0xD5,0xC3,0xDD,0x99,0x0A,0xED,0x53};
 
+  Database(const Database&);
+  Database& operator=(const Database&);
   Database() : name(), description(), locationUri(), ownerName(), ownerType((PrincipalType::type)0) {
   }
 
-  virtual ~Database() throw() {}
-
+  virtual ~Database() throw();
   std::string name;
   std::string description;
   std::string locationUri;
@@ -1230,36 +1369,19 @@ class Database {
 
   _Database__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
-  void __set_description(const std::string& val) {
-    description = val;
-  }
+  void __set_description(const std::string& val);
 
-  void __set_locationUri(const std::string& val) {
-    locationUri = val;
-  }
+  void __set_locationUri(const std::string& val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_privileges(const PrincipalPrivilegeSet& val) {
-    privileges = val;
-    __isset.privileges = true;
-  }
+  void __set_privileges(const PrincipalPrivilegeSet& val);
 
-  void __set_ownerName(const std::string& val) {
-    ownerName = val;
-    __isset.ownerName = true;
-  }
+  void __set_ownerName(const std::string& val);
 
-  void __set_ownerType(const PrincipalType::type val) {
-    ownerType = val;
-    __isset.ownerType = true;
-  }
+  void __set_ownerType(const PrincipalType::type val);
 
   bool operator == (const Database & rhs) const
   {
@@ -1294,15 +1416,16 @@ class Database {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Database& obj);
 };
 
 void swap(Database &a, Database &b);
 
 typedef struct _SerDeInfo__isset {
   _SerDeInfo__isset() : name(false), serializationLib(false), parameters(false) {}
-  bool name;
-  bool serializationLib;
-  bool parameters;
+  bool name :1;
+  bool serializationLib :1;
+  bool parameters :1;
 } _SerDeInfo__isset;
 
 class SerDeInfo {
@@ -1311,28 +1434,23 @@ class SerDeInfo {
   static const char* ascii_fingerprint; // = "B1021C32A35A2AEFCD2F57A5424159A7";
   static const uint8_t binary_fingerprint[16]; // = {0xB1,0x02,0x1C,0x32,0xA3,0x5A,0x2A,0xEF,0xCD,0x2F,0x57,0xA5,0x42,0x41,0x59,0xA7};
 
+  SerDeInfo(const SerDeInfo&);
+  SerDeInfo& operator=(const SerDeInfo&);
   SerDeInfo() : name(), serializationLib() {
   }
 
-  virtual ~SerDeInfo() throw() {}
-
+  virtual ~SerDeInfo() throw();
   std::string name;
   std::string serializationLib;
   std::map<std::string, std::string>  parameters;
 
   _SerDeInfo__isset __isset;
 
-  void __set_name(const std::string& val) {
-    name = val;
-  }
+  void __set_name(const std::string& val);
 
-  void __set_serializationLib(const std::string& val) {
-    serializationLib = val;
-  }
+  void __set_serializationLib(const std::string& val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
   bool operator == (const SerDeInfo & rhs) const
   {
@@ -1353,14 +1471,15 @@ class SerDeInfo {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const SerDeInfo& obj);
 };
 
 void swap(SerDeInfo &a, SerDeInfo &b);
 
 typedef struct _Order__isset {
   _Order__isset() : col(false), order(false) {}
-  bool col;
-  bool order;
+  bool col :1;
+  bool order :1;
 } _Order__isset;
 
 class Order {
@@ -1369,23 +1488,20 @@ class Order {
   static const char* ascii_fingerprint; // = "EEBC915CE44901401D881E6091423036";
   static const uint8_t binary_fingerprint[16]; // = {0xEE,0xBC,0x91,0x5C,0xE4,0x49,0x01,0x40,0x1D,0x88,0x1E,0x60,0x91,0x42,0x30,0x36};
 
+  Order(const Order&);
+  Order& operator=(const Order&);
   Order() : col(), order(0) {
   }
 
-  virtual ~Order() throw() {}
-
+  virtual ~Order() throw();
   std::string col;
   int32_t order;
 
   _Order__isset __isset;
 
-  void __set_col(const std::string& val) {
-    col = val;
-  }
+  void __set_col(const std::string& val);
 
-  void __set_order(const int32_t val) {
-    order = val;
-  }
+  void __set_order(const int32_t val);
 
   bool operator == (const Order & rhs) const
   {
@@ -1404,15 +1520,16 @@ class Order {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Order& obj);
 };
 
 void swap(Order &a, Order &b);
 
 typedef struct _SkewedInfo__isset {
   _SkewedInfo__isset() : skewedColNames(false), skewedColValues(false), skewedColValueLocationMaps(false) {}
-  bool skewedColNames;
-  bool skewedColValues;
-  bool skewedColValueLocationMaps;
+  bool skewedColNames :1;
+  bool skewedColValues :1;
+  bool skewedColValueLocationMaps :1;
 } _SkewedInfo__isset;
 
 class SkewedInfo {
@@ -1421,28 +1538,23 @@ class SkewedInfo {
   static const char* ascii_fingerprint; // = "4BF2ED84BC3C3EB297A2AE2FA8427EB1";
   static const uint8_t binary_fingerprint[16]; // = {0x4B,0xF2,0xED,0x84,0xBC,0x3C,0x3E,0xB2,0x97,0xA2,0xAE,0x2F,0xA8,0x42,0x7E,0xB1};
 
+  SkewedInfo(const SkewedInfo&);
+  SkewedInfo& operator=(const SkewedInfo&);
   SkewedInfo() {
   }
 
-  virtual ~SkewedInfo() throw() {}
-
+  virtual ~SkewedInfo() throw();
   std::vector<std::string>  skewedColNames;
   std::vector<std::vector<std::string> >  skewedColValues;
   std::map<std::vector<std::string> , std::string>  skewedColValueLocationMaps;
 
   _SkewedInfo__isset __isset;
 
-  void __set_skewedColNames(const std::vector<std::string> & val) {
-    skewedColNames = val;
-  }
+  void __set_skewedColNames(const std::vector<std::string> & val);
 
-  void __set_skewedColValues(const std::vector<std::vector<std::string> > & val) {
-    skewedColValues = val;
-  }
+  void __set_skewedColValues(const std::vector<std::vector<std::string> > & val);
 
-  void __set_skewedColValueLocationMaps(const std::map<std::vector<std::string> , std::string> & val) {
-    skewedColValueLocationMaps = val;
-  }
+  void __set_skewedColValueLocationMaps(const std::map<std::vector<std::string> , std::string> & val);
 
   bool operator == (const SkewedInfo & rhs) const
   {
@@ -1463,24 +1575,25 @@ class SkewedInfo {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const SkewedInfo& obj);
 };
 
 void swap(SkewedInfo &a, SkewedInfo &b);
 
 typedef struct _StorageDescriptor__isset {
   _StorageDescriptor__isset() : cols(false), location(false), inputFormat(false), outputFormat(false), compressed(false), numBuckets(false), serdeInfo(false), bucketCols(false), sortCols(false), parameters(false), skewedInfo(false), storedAsSubDirectories(false) {}
-  bool cols;
-  bool location;
-  bool inputFormat;
-  bool outputFormat;
-  bool compressed;
-  bool numBuckets;
-  bool serdeInfo;
-  bool bucketCols;
-  bool sortCols;
-  bool parameters;
-  bool skewedInfo;
-  bool storedAsSubDirectories;
+  bool cols :1;
+  bool location :1;
+  bool inputFormat :1;
+  bool outputFormat :1;
+  bool compressed :1;
+  bool numBuckets :1;
+  bool serdeInfo :1;
+  bool bucketCols :1;
+  bool sortCols :1;
+  bool parameters :1;
+  bool skewedInfo :1;
+  bool storedAsSubDirectories :1;
 } _StorageDescriptor__isset;
 
 class StorageDescriptor {
@@ -1489,11 +1602,12 @@ class StorageDescriptor {
   static const char* ascii_fingerprint; // = "CA8C9AA5FE4C32643757D8639CEF0CD7";
   static const uint8_t binary_fingerprint[16]; // = {0xCA,0x8C,0x9A,0xA5,0xFE,0x4C,0x32,0x64,0x37,0x57,0xD8,0x63,0x9C,0xEF,0x0C,0xD7};
 
+  StorageDescriptor(const StorageDescriptor&);
+  StorageDescriptor& operator=(const StorageDescriptor&);
   StorageDescriptor() : location(), inputFormat(), outputFormat(), compressed(0), numBuckets(0), storedAsSubDirectories(0) {
   }
 
-  virtual ~StorageDescriptor() throw() {}
-
+  virtual ~StorageDescriptor() throw();
   std::vector<FieldSchema>  cols;
   std::string location;
   std::string inputFormat;
@@ -1509,55 +1623,29 @@ class StorageDescriptor {
 
   _StorageDescriptor__isset __isset;
 
-  void __set_cols(const std::vector<FieldSchema> & val) {
-    cols = val;
-  }
+  void __set_cols(const std::vector<FieldSchema> & val);
 
-  void __set_location(const std::string& val) {
-    location = val;
-  }
+  void __set_location(const std::string& val);
 
-  void __set_inputFormat(const std::string& val) {
-    inputFormat = val;
-  }
+  void __set_inputFormat(const std::string& val);
 
-  void __set_outputFormat(const std::string& val) {
-    outputFormat = val;
-  }
+  void __set_outputFormat(const std::string& val);
 
-  void __set_compressed(const bool val) {
-    compressed = val;
-  }
+  void __set_compressed(const bool val);
 
-  void __set_numBuckets(const int32_t val) {
-    numBuckets = val;
-  }
+  void __set_numBuckets(const int32_t val);
 
-  void __set_serdeInfo(const SerDeInfo& val) {
-    serdeInfo = val;
-  }
+  void __set_serdeInfo(const SerDeInfo& val);
 
-  void __set_bucketCols(const std::vector<std::string> & val) {
-    bucketCols = val;
-  }
+  void __set_bucketCols(const std::vector<std::string> & val);
 
-  void __set_sortCols(const std::vector<Order> & val) {
-    sortCols = val;
-  }
+  void __set_sortCols(const std::vector<Order> & val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_skewedInfo(const SkewedInfo& val) {
-    skewedInfo = val;
-    __isset.skewedInfo = true;
-  }
+  void __set_skewedInfo(const SkewedInfo& val);
 
-  void __set_storedAsSubDirectories(const bool val) {
-    storedAsSubDirectories = val;
-    __isset.storedAsSubDirectories = true;
-  }
+  void __set_storedAsSubDirectories(const bool val);
 
   bool operator == (const StorageDescriptor & rhs) const
   {
@@ -1600,26 +1688,27 @@ class StorageDescriptor {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const StorageDescriptor& obj);
 };
 
 void swap(StorageDescriptor &a, StorageDescriptor &b);
 
 typedef struct _Table__isset {
   _Table__isset() : tableName(false), dbName(false), owner(false), createTime(false), lastAccessTime(false), retention(false), sd(false), partitionKeys(false), parameters(false), viewOriginalText(false), viewExpandedText(false), tableType(false), privileges(false), temporary(true) {}
-  bool tableName;
-  bool dbName;
-  bool owner;
-  bool createTime;
-  bool lastAccessTime;
-  bool retention;
-  bool sd;
-  bool partitionKeys;
-  bool parameters;
-  bool viewOriginalText;
-  bool viewExpandedText;
-  bool tableType;
-  bool privileges;
-  bool temporary;
+  bool tableName :1;
+  bool dbName :1;
+  bool owner :1;
+  bool createTime :1;
+  bool lastAccessTime :1;
+  bool retention :1;
+  bool sd :1;
+  bool partitionKeys :1;
+  bool parameters :1;
+  bool viewOriginalText :1;
+  bool viewExpandedText :1;
+  bool tableType :1;
+  bool privileges :1;
+  bool temporary :1;
 } _Table__isset;
 
 class Table {
@@ -1628,11 +1717,12 @@ class Table {
   static const char* ascii_fingerprint; // = "29EFB2A5970EF572039E5D94CC78AA85";
   static const uint8_t binary_fingerprint[16]; // = {0x29,0xEF,0xB2,0xA5,0x97,0x0E,0xF5,0x72,0x03,0x9E,0x5D,0x94,0xCC,0x78,0xAA,0x85};
 
+  Table(const Table&);
+  Table& operator=(const Table&);
   Table() : tableName(), dbName(), owner(), createTime(0), lastAccessTime(0), retention(0), viewOriginalText(), viewExpandedText(), tableType(), temporary(false) {
   }
 
-  virtual ~Table() throw() {}
-
+  virtual ~Table() throw();
   std::string tableName;
   std::string dbName;
   std::string owner;
@@ -1650,63 +1740,33 @@ class Table {
 
   _Table__isset __isset;
 
-  void __set_tableName(const std::string& val) {
-    tableName = val;
-  }
+  void __set_tableName(const std::string& val);
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_owner(const std::string& val) {
-    owner = val;
-  }
+  void __set_owner(const std::string& val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_lastAccessTime(const int32_t val) {
-    lastAccessTime = val;
-  }
+  void __set_lastAccessTime(const int32_t val);
 
-  void __set_retention(const int32_t val) {
-    retention = val;
-  }
+  void __set_retention(const int32_t val);
 
-  void __set_sd(const StorageDescriptor& val) {
-    sd = val;
-  }
+  void __set_sd(const StorageDescriptor& val);
 
-  void __set_partitionKeys(const std::vector<FieldSchema> & val) {
-    partitionKeys = val;
-  }
+  void __set_partitionKeys(const std::vector<FieldSchema> & val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_viewOriginalText(const std::string& val) {
-    viewOriginalText = val;
-  }
+  void __set_viewOriginalText(const std::string& val);
 
-  void __set_viewExpandedText(const std::string& val) {
-    viewExpandedText = val;
-  }
+  void __set_viewExpandedText(const std::string& val);
 
-  void __set_tableType(const std::string& val) {
-    tableType = val;
-  }
+  void __set_tableType(const std::string& val);
 
-  void __set_privileges(const PrincipalPrivilegeSet& val) {
-    privileges = val;
-    __isset.privileges = true;
-  }
+  void __set_privileges(const PrincipalPrivilegeSet& val);
 
-  void __set_temporary(const bool val) {
-    temporary = val;
-    __isset.temporary = true;
-  }
+  void __set_temporary(const bool val);
 
   bool operator == (const Table & rhs) const
   {
@@ -1753,20 +1813,21 @@ class Table {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Table& obj);
 };
 
 void swap(Table &a, Table &b);
 
 typedef struct _Partition__isset {
   _Partition__isset() : values(false), dbName(false), tableName(false), createTime(false), lastAccessTime(false), sd(false), parameters(false), privileges(false) {}
-  bool values;
-  bool dbName;
-  bool tableName;
-  bool createTime;
-  bool lastAccessTime;
-  bool sd;
-  bool parameters;
-  bool privileges;
+  bool values :1;
+  bool dbName :1;
+  bool tableName :1;
+  bool createTime :1;
+  bool lastAccessTime :1;
+  bool sd :1;
+  bool parameters :1;
+  bool privileges :1;
 } _Partition__isset;
 
 class Partition {
@@ -1775,11 +1836,12 @@ class Partition {
   static const char* ascii_fingerprint; // = "31A52241B88A426C34087FE38343FF51";
   static const uint8_t binary_fingerprint[16]; // = {0x31,0xA5,0x22,0x41,0xB8,0x8A,0x42,0x6C,0x34,0x08,0x7F,0xE3,0x83,0x43,0xFF,0x51};
 
+  Partition(const Partition&);
+  Partition& operator=(const Partition&);
   Partition() : dbName(), tableName(), createTime(0), lastAccessTime(0) {
   }
 
-  virtual ~Partition() throw() {}
-
+  virtual ~Partition() throw();
   std::vector<std::string>  values;
   std::string dbName;
   std::string tableName;
@@ -1791,38 +1853,21 @@ class Partition {
 
   _Partition__isset __isset;
 
-  void __set_values(const std::vector<std::string> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<std::string> & val);
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_tableName(const std::string& val) {
-    tableName = val;
-  }
+  void __set_tableName(const std::string& val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_lastAccessTime(const int32_t val) {
-    lastAccessTime = val;
-  }
+  void __set_lastAccessTime(const int32_t val);
 
-  void __set_sd(const StorageDescriptor& val) {
-    sd = val;
-  }
+  void __set_sd(const StorageDescriptor& val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_privileges(const PrincipalPrivilegeSet& val) {
-    privileges = val;
-    __isset.privileges = true;
-  }
+  void __set_privileges(const PrincipalPrivilegeSet& val);
 
   bool operator == (const Partition & rhs) const
   {
@@ -1855,18 +1900,19 @@ class Partition {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Partition& obj);
 };
 
 void swap(Partition &a, Partition &b);
 
 typedef struct _PartitionWithoutSD__isset {
   _PartitionWithoutSD__isset() : values(false), createTime(false), lastAccessTime(false), relativePath(false), parameters(false), privileges(false) {}
-  bool values;
-  bool createTime;
-  bool lastAccessTime;
-  bool relativePath;
-  bool parameters;
-  bool privileges;
+  bool values :1;
+  bool createTime :1;
+  bool lastAccessTime :1;
+  bool relativePath :1;
+  bool parameters :1;
+  bool privileges :1;
 } _PartitionWithoutSD__isset;
 
 class PartitionWithoutSD {
@@ -1875,11 +1921,12 @@ class PartitionWithoutSD {
   static const char* ascii_fingerprint; // = "D79FA44499888D0E50B5625E0C536DEA";
   static const uint8_t binary_fingerprint[16]; // = {0xD7,0x9F,0xA4,0x44,0x99,0x88,0x8D,0x0E,0x50,0xB5,0x62,0x5E,0x0C,0x53,0x6D,0xEA};
 
+  PartitionWithoutSD(const PartitionWithoutSD&);
+  PartitionWithoutSD& operator=(const PartitionWithoutSD&);
   PartitionWithoutSD() : createTime(0), lastAccessTime(0), relativePath() {
   }
 
-  virtual ~PartitionWithoutSD() throw() {}
-
+  virtual ~PartitionWithoutSD() throw();
   std::vector<std::string>  values;
   int32_t createTime;
   int32_t lastAccessTime;
@@ -1889,30 +1936,17 @@ class PartitionWithoutSD {
 
   _PartitionWithoutSD__isset __isset;
 
-  void __set_values(const std::vector<std::string> & val) {
-    values = val;
-  }
+  void __set_values(const std::vector<std::string> & val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_lastAccessTime(const int32_t val) {
-    lastAccessTime = val;
-  }
+  void __set_lastAccessTime(const int32_t val);
 
-  void __set_relativePath(const std::string& val) {
-    relativePath = val;
-  }
+  void __set_relativePath(const std::string& val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_privileges(const PrincipalPrivilegeSet& val) {
-    privileges = val;
-    __isset.privileges = true;
-  }
+  void __set_privileges(const PrincipalPrivilegeSet& val);
 
   bool operator == (const PartitionWithoutSD & rhs) const
   {
@@ -1941,14 +1975,15 @@ class PartitionWithoutSD {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PartitionWithoutSD& obj);
 };
 
 void swap(PartitionWithoutSD &a, PartitionWithoutSD &b);
 
 typedef struct _PartitionSpecWithSharedSD__isset {
   _PartitionSpecWithSharedSD__isset() : partitions(false), sd(false) {}
-  bool partitions;
-  bool sd;
+  bool partitions :1;
+  bool sd :1;
 } _PartitionSpecWithSharedSD__isset;
 
 class PartitionSpecWithSharedSD {
@@ -1957,23 +1992,20 @@ class PartitionSpecWithSharedSD {
   static const char* ascii_fingerprint; // = "7BEE9305B42DCD083FF06BEE6DDC61CF";
   static const uint8_t binary_fingerprint[16]; // = {0x7B,0xEE,0x93,0x05,0xB4,0x2D,0xCD,0x08,0x3F,0xF0,0x6B,0xEE,0x6D,0xDC,0x61,0xCF};
 
+  PartitionSpecWithSharedSD(const PartitionSpecWithSharedSD&);
+  PartitionSpecWithSharedSD& operator=(const PartitionSpecWithSharedSD&);
   PartitionSpecWithSharedSD() {
   }
 
-  virtual ~PartitionSpecWithSharedSD() throw() {}
-
+  virtual ~PartitionSpecWithSharedSD() throw();
   std::vector<PartitionWithoutSD>  partitions;
   StorageDescriptor sd;
 
   _PartitionSpecWithSharedSD__isset __isset;
 
-  void __set_partitions(const std::vector<PartitionWithoutSD> & val) {
-    partitions = val;
-  }
+  void __set_partitions(const std::vector<PartitionWithoutSD> & val);
 
-  void __set_sd(const StorageDescriptor& val) {
-    sd = val;
-  }
+  void __set_sd(const StorageDescriptor& val);
 
   bool operator == (const PartitionSpecWithSharedSD & rhs) const
   {
@@ -1992,13 +2024,14 @@ class PartitionSpecWithSharedSD {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PartitionSpecWithSharedSD& obj);
 };
 
 void swap(PartitionSpecWithSharedSD &a, PartitionSpecWithSharedSD &b);
 
 typedef struct _PartitionListComposingSpec__isset {
   _PartitionListComposingSpec__isset() : partitions(false) {}
-  bool partitions;
+  bool partitions :1;
 } _PartitionListComposingSpec__isset;
 
 class PartitionListComposingSpec {
@@ -2007,18 +2040,17 @@ class PartitionListComposingSpec {
   static const char* ascii_fingerprint; // = "A048235CB9A257C8A74E3691BEFE0674";
   static const uint8_t binary_fingerprint[16]; // = {0xA0,0x48,0x23,0x5C,0xB9,0xA2,0x57,0xC8,0xA7,0x4E,0x36,0x91,0xBE,0xFE,0x06,0x74};
 
+  PartitionListComposingSpec(const PartitionListComposingSpec&);
+  PartitionListComposingSpec& operator=(const PartitionListComposingSpec&);
   PartitionListComposingSpec() {
   }
 
-  virtual ~PartitionListComposingSpec() throw() {}
-
+  virtual ~PartitionListComposingSpec() throw();
   std::vector<Partition>  partitions;
 
   _PartitionListComposingSpec__isset __isset;
 
-  void __set_partitions(const std::vector<Partition> & val) {
-    partitions = val;
-  }
+  void __set_partitions(const std::vector<Partition> & val);
 
   bool operator == (const PartitionListComposingSpec & rhs) const
   {
@@ -2035,17 +2067,18 @@ class PartitionListComposingSpec {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PartitionListComposingSpec& obj);
 };
 
 void swap(PartitionListComposingSpec &a, PartitionListComposingSpec &b);
 
 typedef struct _PartitionSpec__isset {
   _PartitionSpec__isset() : dbName(false), tableName(false), rootPath(false), sharedSDPartitionSpec(false), partitionList(false) {}
-  bool dbName;
-  bool tableName;
-  bool rootPath;
-  bool sharedSDPartitionSpec;
-  bool partitionList;
+  bool dbName :1;
+  bool tableName :1;
+  bool rootPath :1;
+  bool sharedSDPartitionSpec :1;
+  bool partitionList :1;
 } _PartitionSpec__isset;
 
 class PartitionSpec {
@@ -2054,11 +2087,12 @@ class PartitionSpec {
   static const char* ascii_fingerprint; // = "C3F548C24D072CF6422F25096143E3E8";
   static const uint8_t binary_fingerprint[16]; // = {0xC3,0xF5,0x48,0xC2,0x4D,0x07,0x2C,0xF6,0x42,0x2F,0x25,0x09,0x61,0x43,0xE3,0xE8};
 
+  PartitionSpec(const PartitionSpec&);
+  PartitionSpec& operator=(const PartitionSpec&);
   PartitionSpec() : dbName(), tableName(), rootPath() {
   }
 
-  virtual ~PartitionSpec() throw() {}
-
+  virtual ~PartitionSpec() throw();
   std::string dbName;
   std::string tableName;
   std::string rootPath;
@@ -2067,27 +2101,15 @@ class PartitionSpec {
 
   _PartitionSpec__isset __isset;
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_tableName(const std::string& val) {
-    tableName = val;
-  }
+  void __set_tableName(const std::string& val);
 
-  void __set_rootPath(const std::string& val) {
-    rootPath = val;
-  }
+  void __set_rootPath(const std::string& val);
 
-  void __set_sharedSDPartitionSpec(const PartitionSpecWithSharedSD& val) {
-    sharedSDPartitionSpec = val;
-    __isset.sharedSDPartitionSpec = true;
-  }
+  void __set_sharedSDPartitionSpec(const PartitionSpecWithSharedSD& val);
 
-  void __set_partitionList(const PartitionListComposingSpec& val) {
-    partitionList = val;
-    __isset.partitionList = true;
-  }
+  void __set_partitionList(const PartitionListComposingSpec& val);
 
   bool operator == (const PartitionSpec & rhs) const
   {
@@ -2116,22 +2138,23 @@ class PartitionSpec {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const PartitionSpec& obj);
 };
 
 void swap(PartitionSpec &a, PartitionSpec &b);
 
 typedef struct _Index__isset {
   _Index__isset() : indexName(false), indexHandlerClass(false), dbName(false), origTableName(false), createTime(false), lastAccessTime(false), indexTableName(false), sd(false), parameters(false), deferredRebuild(false) {}
-  bool indexName;
-  bool indexHandlerClass;
-  bool dbName;
-  bool origTableName;
-  bool createTime;
-  bool lastAccessTime;
-  bool indexTableName;
-  bool sd;
-  bool parameters;
-  bool deferredRebuild;
+  bool indexName :1;
+  bool indexHandlerClass :1;
+  bool dbName :1;
+  bool origTableName :1;
+  bool createTime :1;
+  bool lastAccessTime :1;
+  bool indexTableName :1;
+  bool sd :1;
+  bool parameters :1;
+  bool deferredRebuild :1;
 } _Index__isset;
 
 class Index {
@@ -2140,11 +2163,12 @@ class Index {
   static const char* ascii_fingerprint; // = "09EEF655216AC81802850988D6C470A6";
   static const uint8_t binary_fingerprint[16]; // = {0x09,0xEE,0xF6,0x55,0x21,0x6A,0xC8,0x18,0x02,0x85,0x09,0x88,0xD6,0xC4,0x70,0xA6};
 
+  Index(const Index&);
+  Index& operator=(const Index&);
   Index() : indexName(), indexHandlerClass(), dbName(), origTableName(), createTime(0), lastAccessTime(0), indexTableName(), deferredRebuild(0) {
   }
 
-  virtual ~Index() throw() {}
-
+  virtual ~Index() throw();
   std::string indexName;
   std::string indexHandlerClass;
   std::string dbName;
@@ -2158,45 +2182,25 @@ class Index {
 
   _Index__isset __isset;
 
-  void __set_indexName(const std::string& val) {
-    indexName = val;
-  }
+  void __set_indexName(const std::string& val);
 
-  void __set_indexHandlerClass(const std::string& val) {
-    indexHandlerClass = val;
-  }
+  void __set_indexHandlerClass(const std::string& val);
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_origTableName(const std::string& val) {
-    origTableName = val;
-  }
+  void __set_origTableName(const std::string& val);
 
-  void __set_createTime(const int32_t val) {
-    createTime = val;
-  }
+  void __set_createTime(const int32_t val);
 
-  void __set_lastAccessTime(const int32_t val) {
-    lastAccessTime = val;
-  }
+  void __set_lastAccessTime(const int32_t val);
 
-  void __set_indexTableName(const std::string& val) {
-    indexTableName = val;
-  }
+  void __set_indexTableName(const std::string& val);
 
-  void __set_sd(const StorageDescriptor& val) {
-    sd = val;
-  }
+  void __set_sd(const StorageDescriptor& val);
 
-  void __set_parameters(const std::map<std::string, std::string> & val) {
-    parameters = val;
-  }
+  void __set_parameters(const std::map<std::string, std::string> & val);
 
-  void __set_deferredRebuild(const bool val) {
-    deferredRebuild = val;
-  }
+  void __set_deferredRebuild(const bool val);
 
   bool operator == (const Index & rhs) const
   {
@@ -2231,6 +2235,7 @@ class Index {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Index& obj);
 };
 
 void swap(Index &a, Index &b);
@@ -2242,26 +2247,21 @@ class BooleanColumnStatsData {
   static const char* ascii_fingerprint; // = "EA2D65F1E0BB78760205682082304B41";
   static const uint8_t binary_fingerprint[16]; // = {0xEA,0x2D,0x65,0xF1,0xE0,0xBB,0x78,0x76,0x02,0x05,0x68,0x20,0x82,0x30,0x4B,0x41};
 
+  BooleanColumnStatsData(const BooleanColumnStatsData&);
+  BooleanColumnStatsData& operator=(const BooleanColumnStatsData&);
   BooleanColumnStatsData() : numTrues(0), numFalses(0), numNulls(0) {
   }
 
-  virtual ~BooleanColumnStatsData() throw() {}
-
+  virtual ~BooleanColumnStatsData() throw();
   int64_t numTrues;
   int64_t numFalses;
   int64_t numNulls;
 
-  void __set_numTrues(const int64_t val) {
-    numTrues = val;
-  }
+  void __set_numTrues(const int64_t val);
 
-  void __set_numFalses(const int64_t val) {
-    numFalses = val;
-  }
+  void __set_numFalses(const int64_t val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
   bool operator == (const BooleanColumnStatsData & rhs) const
   {
@@ -2282,14 +2282,15 @@ class BooleanColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const BooleanColumnStatsData& obj);
 };
 
 void swap(BooleanColumnStatsData &a, BooleanColumnStatsData &b);
 
 typedef struct _DoubleColumnStatsData__isset {
   _DoubleColumnStatsData__isset() : lowValue(false), highValue(false) {}
-  bool lowValue;
-  bool highValue;
+  bool lowValue :1;
+  bool highValue :1;
 } _DoubleColumnStatsData__isset;
 
 class DoubleColumnStatsData {
@@ -2298,11 +2299,12 @@ class DoubleColumnStatsData {
   static const char* ascii_fingerprint; // = "DA7C011321D74C48396AA002E61A0CBB";
   static const uint8_t binary_fingerprint[16]; // = {0xDA,0x7C,0x01,0x13,0x21,0xD7,0x4C,0x48,0x39,0x6A,0xA0,0x02,0xE6,0x1A,0x0C,0xBB};
 
+  DoubleColumnStatsData(const DoubleColumnStatsData&);
+  DoubleColumnStatsData& operator=(const DoubleColumnStatsData&);
   DoubleColumnStatsData() : lowValue(0), highValue(0), numNulls(0), numDVs(0) {
   }
 
-  virtual ~DoubleColumnStatsData() throw() {}
-
+  virtual ~DoubleColumnStatsData() throw();
   double lowValue;
   double highValue;
   int64_t numNulls;
@@ -2310,23 +2312,13 @@ class DoubleColumnStatsData {
 
   _DoubleColumnStatsData__isset __isset;
 
-  void __set_lowValue(const double val) {
-    lowValue = val;
-    __isset.lowValue = true;
-  }
+  void __set_lowValue(const double val);
 
-  void __set_highValue(const double val) {
-    highValue = val;
-    __isset.highValue = true;
-  }
+  void __set_highValue(const double val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
-  void __set_numDVs(const int64_t val) {
-    numDVs = val;
-  }
+  void __set_numDVs(const int64_t val);
 
   bool operator == (const DoubleColumnStatsData & rhs) const
   {
@@ -2353,14 +2345,15 @@ class DoubleColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const DoubleColumnStatsData& obj);
 };
 
 void swap(DoubleColumnStatsData &a, DoubleColumnStatsData &b);
 
 typedef struct _LongColumnStatsData__isset {
   _LongColumnStatsData__isset() : lowValue(false), highValue(false) {}
-  bool lowValue;
-  bool highValue;
+  bool lowValue :1;
+  bool highValue :1;
 } _LongColumnStatsData__isset;
 
 class LongColumnStatsData {
@@ -2369,11 +2362,12 @@ class LongColumnStatsData {
   static const char* ascii_fingerprint; // = "E685FC220B24E3B8B93604790DCB9AEA";
   static const uint8_t binary_fingerprint[16]; // = {0xE6,0x85,0xFC,0x22,0x0B,0x24,0xE3,0xB8,0xB9,0x36,0x04,0x79,0x0D,0xCB,0x9A,0xEA};
 
+  LongColumnStatsData(const LongColumnStatsData&);
+  LongColumnStatsData& operator=(const LongColumnStatsData&);
   LongColumnStatsData() : lowValue(0), highValue(0), numNulls(0), numDVs(0) {
   }
 
-  virtual ~LongColumnStatsData() throw() {}
-
+  virtual ~LongColumnStatsData() throw();
   int64_t lowValue;
   int64_t highValue;
   int64_t numNulls;
@@ -2381,23 +2375,13 @@ class LongColumnStatsData {
 
   _LongColumnStatsData__isset __isset;
 
-  void __set_lowValue(const int64_t val) {
-    lowValue = val;
-    __isset.lowValue = true;
-  }
+  void __set_lowValue(const int64_t val);
 
-  void __set_highValue(const int64_t val) {
-    highValue = val;
-    __isset.highValue = true;
-  }
+  void __set_highValue(const int64_t val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
-  void __set_numDVs(const int64_t val) {
-    numDVs = val;
-  }
+  void __set_numDVs(const int64_t val);
 
   bool operator == (const LongColumnStatsData & rhs) const
   {
@@ -2424,6 +2408,7 @@ class LongColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const LongColumnStatsData& obj);
 };
 
 void swap(LongColumnStatsData &a, LongColumnStatsData &b);
@@ -2435,31 +2420,24 @@ class StringColumnStatsData {
   static const char* ascii_fingerprint; // = "D017B08C3DF12C3AB98788B2E67DAAB3";
   static const uint8_t binary_fingerprint[16]; // = {0xD0,0x17,0xB0,0x8C,0x3D,0xF1,0x2C,0x3A,0xB9,0x87,0x88,0xB2,0xE6,0x7D,0xAA,0xB3};
 
+  StringColumnStatsData(const StringColumnStatsData&);
+  StringColumnStatsData& operator=(const StringColumnStatsData&);
   StringColumnStatsData() : maxColLen(0), avgColLen(0), numNulls(0), numDVs(0) {
   }
 
-  virtual ~StringColumnStatsData() throw() {}
-
+  virtual ~StringColumnStatsData() throw();
   int64_t maxColLen;
   double avgColLen;
   int64_t numNulls;
   int64_t numDVs;
 
-  void __set_maxColLen(const int64_t val) {
-    maxColLen = val;
-  }
+  void __set_maxColLen(const int64_t val);
 
-  void __set_avgColLen(const double val) {
-    avgColLen = val;
-  }
+  void __set_avgColLen(const double val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
-  void __set_numDVs(const int64_t val) {
-    numDVs = val;
-  }
+  void __set_numDVs(const int64_t val);
 
   bool operator == (const StringColumnStatsData & rhs) const
   {
@@ -2482,6 +2460,7 @@ class StringColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const StringColumnStatsData& obj);
 };
 
 void swap(StringColumnStatsData &a, StringColumnStatsData &b);
@@ -2493,26 +2472,21 @@ class BinaryColumnStatsData {
   static const char* ascii_fingerprint; // = "22B0CB67183FCDB945892B9974518D06";
   static const uint8_t binary_fingerprint[16]; // = {0x22,0xB0,0xCB,0x67,0x18,0x3F,0xCD,0xB9,0x45,0x89,0x2B,0x99,0x74,0x51,0x8D,0x06};
 
+  BinaryColumnStatsData(const BinaryColumnStatsData&);
+  BinaryColumnStatsData& operator=(const BinaryColumnStatsData&);
   BinaryColumnStatsData() : maxColLen(0), avgColLen(0), numNulls(0) {
   }
 
-  virtual ~BinaryColumnStatsData() throw() {}
-
+  virtual ~BinaryColumnStatsData() throw();
   int64_t maxColLen;
   double avgColLen;
   int64_t numNulls;
 
-  void __set_maxColLen(const int64_t val) {
-    maxColLen = val;
-  }
+  void __set_maxColLen(const int64_t val);
 
-  void __set_avgColLen(const double val) {
-    avgColLen = val;
-  }
+  void __set_avgColLen(const double val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
   bool operator == (const BinaryColumnStatsData & rhs) const
   {
@@ -2533,6 +2507,7 @@ class BinaryColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const BinaryColumnStatsData& obj);
 };
 
 void swap(BinaryColumnStatsData &a, BinaryColumnStatsData &b);
@@ -2544,21 +2519,18 @@ class Decimal {
   static const char* ascii_fingerprint; // = "C4DDF6759F9B17C5C380806CE743DE8E";
   static const uint8_t binary_fingerprint[16]; // = {0xC4,0xDD,0xF6,0x75,0x9F,0x9B,0x17,0xC5,0xC3,0x80,0x80,0x6C,0xE7,0x43,0xDE,0x8E};
 
+  Decimal(const Decimal&);
+  Decimal& operator=(const Decimal&);
   Decimal() : unscaled(), scale(0) {
   }
 
-  virtual ~Decimal() throw() {}
-
+  virtual ~Decimal() throw();
   std::string unscaled;
   int16_t scale;
 
-  void __set_unscaled(const std::string& val) {
-    unscaled = val;
-  }
+  void __set_unscaled(const std::string& val);
 
-  void __set_scale(const int16_t val) {
-    scale = val;
-  }
+  void __set_scale(const int16_t val);
 
   bool operator == (const Decimal & rhs) const
   {
@@ -2577,14 +2549,15 @@ class Decimal {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Decimal& obj);
 };
 
 void swap(Decimal &a, Decimal &b);
 
 typedef struct _DecimalColumnStatsData__isset {
   _DecimalColumnStatsData__isset() : lowValue(false), highValue(false) {}
-  bool lowValue;
-  bool highValue;
+  bool lowValue :1;
+  bool highValue :1;
 } _DecimalColumnStatsData__isset;
 
 class DecimalColumnStatsData {
@@ -2593,11 +2566,12 @@ class DecimalColumnStatsData {
   static const char* ascii_fingerprint; // = "B6D47E7A28922BFA93FE05E9F1B04748";
   static const uint8_t binary_fingerprint[16]; // = {0xB6,0xD4,0x7E,0x7A,0x28,0x92,0x2B,0xFA,0x93,0xFE,0x05,0xE9,0xF1,0xB0,0x47,0x48};
 
+  DecimalColumnStatsData(const DecimalColumnStatsData&);
+  DecimalColumnStatsData& operator=(const DecimalColumnStatsData&);
   DecimalColumnStatsData() : numNulls(0), numDVs(0) {
   }
 
-  virtual ~DecimalColumnStatsData() throw() {}
-
+  virtual ~DecimalColumnStatsData() throw();
   Decimal lowValue;
   Decimal highValue;
   int64_t numNulls;
@@ -2605,23 +2579,13 @@ class DecimalColumnStatsData {
 
   _DecimalColumnStatsData__isset __isset;
 
-  void __set_lowValue(const Decimal& val) {
-    lowValue = val;
-    __isset.lowValue = true;
-  }
+  void __set_lowValue(const Decimal& val);
 
-  void __set_highValue(const Decimal& val) {
-    highValue = val;
-    __isset.highValue = true;
-  }
+  void __set_highValue(const Decimal& val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
-  void __set_numDVs(const int64_t val) {
-    numDVs = val;
-  }
+  void __set_numDVs(const int64_t val);
 
   bool operator == (const DecimalColumnStatsData & rhs) const
   {
@@ -2648,6 +2612,7 @@ class DecimalColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const DecimalColumnStatsData& obj);
 };
 
 void swap(DecimalColumnStatsData &a, DecimalColumnStatsData &b);
@@ -2659,16 +2624,15 @@ class Date {
   static const char* ascii_fingerprint; // = "56A59CE7FFAF82BCA8A19FAACDE4FB75";
   static const uint8_t binary_fingerprint[16]; // = {0x56,0xA5,0x9C,0xE7,0xFF,0xAF,0x82,0xBC,0xA8,0xA1,0x9F,0xAA,0xCD,0xE4,0xFB,0x75};
 
+  Date(const Date&);
+  Date& operator=(const Date&);
   Date() : daysSinceEpoch(0) {
   }
 
-  virtual ~Date() throw() {}
-
+  virtual ~Date() throw();
   int64_t daysSinceEpoch;
 
-  void __set_daysSinceEpoch(const int64_t val) {
-    daysSinceEpoch = val;
-  }
+  void __set_daysSinceEpoch(const int64_t val);
 
   bool operator == (const Date & rhs) const
   {
@@ -2685,14 +2649,15 @@ class Date {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const Date& obj);
 };
 
 void swap(Date &a, Date &b);
 
 typedef struct _DateColumnStatsData__isset {
   _DateColumnStatsData__isset() : lowValue(false), highValue(false) {}
-  bool lowValue;
-  bool highValue;
+  bool lowValue :1;
+  bool highValue :1;
 } _DateColumnStatsData__isset;
 
 class DateColumnStatsData {
@@ -2701,11 +2666,12 @@ class DateColumnStatsData {
   static const char* ascii_fingerprint; // = "D0719F3BBA8248297BB5287552897F59";
   static const uint8_t binary_fingerprint[16]; // = {0xD0,0x71,0x9F,0x3B,0xBA,0x82,0x48,0x29,0x7B,0xB5,0x28,0x75,0x52,0x89,0x7F,0x59};
 
+  DateColumnStatsData(const DateColumnStatsData&);
+  DateColumnStatsData& operator=(const DateColumnStatsData&);
   DateColumnStatsData() : numNulls(0), numDVs(0) {
   }
 
-  virtual ~DateColumnStatsData() throw() {}
-
+  virtual ~DateColumnStatsData() throw();
   Date lowValue;
   Date highValue;
   int64_t numNulls;
@@ -2713,23 +2679,13 @@ class DateColumnStatsData {
 
   _DateColumnStatsData__isset __isset;
 
-  void __set_lowValue(const Date& val) {
-    lowValue = val;
-    __isset.lowValue = true;
-  }
+  void __set_lowValue(const Date& val);
 
-  void __set_highValue(const Date& val) {
-    highValue = val;
-    __isset.highValue = true;
-  }
+  void __set_highValue(const Date& val);
 
-  void __set_numNulls(const int64_t val) {
-    numNulls = val;
-  }
+  void __set_numNulls(const int64_t val);
 
-  void __set_numDVs(const int64_t val) {
-    numDVs = val;
-  }
+  void __set_numDVs(const int64_t val);
 
   bool operator == (const DateColumnStatsData & rhs) const
   {
@@ -2756,19 +2712,20 @@ class DateColumnStatsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const DateColumnStatsData& obj);
 };
 
 void swap(DateColumnStatsData &a, DateColumnStatsData &b);
 
 typedef struct _ColumnStatisticsData__isset {
   _ColumnStatisticsData__isset() : booleanStats(false), longStats(false), doubleStats(false), stringStats(false), binaryStats(false), decimalStats(false), dateStats(false) {}
-  bool booleanStats;
-  bool longStats;
-  bool doubleStats;
-  bool stringStats;
-  bool binaryStats;
-  bool decimalStats;
-  bool dateStats;
+  bool booleanStats :1;
+  bool longStats :1;
+  bool doubleStats :1;
+  bool stringStats :1;
+  bool binaryStats :1;
+  bool decimalStats :1;
+  bool dateStats :1;
 } _ColumnStatisticsData__isset;
 
 class ColumnStatisticsData {
@@ -2777,11 +2734,12 @@ class ColumnStatisticsData {
   static const char* ascii_fingerprint; // = "15E449CA15A23E37F2D54C31ACA52106";
   static const uint8_t binary_fingerprint[16]; // = {0x15,0xE4,0x49,0xCA,0x15,0xA2,0x3E,0x37,0xF2,0xD5,0x4C,0x31,0xAC,0xA5,0x21,0x06};
 
+  ColumnStatisticsData(const ColumnStatisticsData&);
+  ColumnStatisticsData& operator=(const ColumnStatisticsData&);
   ColumnStatisticsData() {
   }
 
-  virtual ~ColumnStatisticsData() throw() {}
-
+  virtual ~ColumnStatisticsData() throw();
   BooleanColumnStatsData booleanStats;
   LongColumnStatsData longStats;
   DoubleColumnStatsData doubleStats;
@@ -2792,33 +2750,19 @@ class ColumnStatisticsData {
 
   _ColumnStatisticsData__isset __isset;
 
-  void __set_booleanStats(const BooleanColumnStatsData& val) {
-    booleanStats = val;
-  }
+  void __set_booleanStats(const BooleanColumnStatsData& val);
 
-  void __set_longStats(const LongColumnStatsData& val) {
-    longStats = val;
-  }
+  void __set_longStats(const LongColumnStatsData& val);
 
-  void __set_doubleStats(const DoubleColumnStatsData& val) {
-    doubleStats = val;
-  }
+  void __set_doubleStats(const DoubleColumnStatsData& val);
 
-  void __set_stringStats(const StringColumnStatsData& val) {
-    stringStats = val;
-  }
+  void __set_stringStats(const StringColumnStatsData& val);
 
-  void __set_binaryStats(const BinaryColumnStatsData& val) {
-    binaryStats = val;
-  }
+  void __set_binaryStats(const BinaryColumnStatsData& val);
 
-  void __set_decimalStats(const DecimalColumnStatsData& val) {
-    decimalStats = val;
-  }
+  void __set_decimalStats(const DecimalColumnStatsData& val);
 
-  void __set_dateStats(const DateColumnStatsData& val) {
-    dateStats = val;
-  }
+  void __set_dateStats(const DateColumnStatsData& val);
 
   bool operator == (const ColumnStatisticsData & rhs) const
   {
@@ -2847,6 +2791,7 @@ class ColumnStatisticsData {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ColumnStatisticsData& obj);
 };
 
 void swap(ColumnStatisticsData &a, ColumnStatisticsData &b);
@@ -2858,26 +2803,21 @@ class ColumnStatisticsObj {
   static const char* ascii_fingerprint; // = "A82BA819C9FFEDDEBC0D50F6F4E46534";
   static const uint8_t binary_fingerprint[16]; // = {0xA8,0x2B,0xA8,0x19,0xC9,0xFF,0xED,0xDE,0xBC,0x0D,0x50,0xF6,0xF4,0xE4,0x65,0x34};
 
+  ColumnStatisticsObj(const ColumnStatisticsObj&);
+  ColumnStatisticsObj& operator=(const ColumnStatisticsObj&);
   ColumnStatisticsObj() : colName(), colType() {
   }
 
-  virtual ~ColumnStatisticsObj() throw() {}
-
+  virtual ~ColumnStatisticsObj() throw();
   std::string colName;
   std::string colType;
   ColumnStatisticsData statsData;
 
-  void __set_colName(const std::string& val) {
-    colName = val;
-  }
+  void __set_colName(const std::string& val);
 
-  void __set_colType(const std::string& val) {
-    colType = val;
-  }
+  void __set_colType(const std::string& val);
 
-  void __set_statsData(const ColumnStatisticsData& val) {
-    statsData = val;
-  }
+  void __set_statsData(const ColumnStatisticsData& val);
 
   bool operator == (const ColumnStatisticsObj & rhs) const
   {
@@ -2898,14 +2838,15 @@ class ColumnStatisticsObj {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ColumnStatisticsObj& obj);
 };
 
 void swap(ColumnStatisticsObj &a, ColumnStatisticsObj &b);
 
 typedef struct _ColumnStatisticsDesc__isset {
   _ColumnStatisticsDesc__isset() : partName(false), lastAnalyzed(false) {}
-  bool partName;
-  bool lastAnalyzed;
+  bool partName :1;
+  bool lastAnalyzed :1;
 } _ColumnStatisticsDesc__isset;
 
 class ColumnStatisticsDesc {
@@ -2914,11 +2855,12 @@ class ColumnStatisticsDesc {
   static const char* ascii_fingerprint; // = "261759FF6F8FAB53F941453007FE18CB";
   static const uint8_t binary_fingerprint[16]; // = {0x26,0x17,0x59,0xFF,0x6F,0x8F,0xAB,0x53,0xF9,0x41,0x45,0x30,0x07,0xFE,0x18,0xCB};
 
+  ColumnStatisticsDesc(const ColumnStatisticsDesc&);
+  ColumnStatisticsDesc& operator=(const ColumnStatisticsDesc&);
   ColumnStatisticsDesc() : isTblLevel(0), dbName(), tableName(), partName(), lastAnalyzed(0) {
   }
 
-  virtual ~ColumnStatisticsDesc() throw() {}
-
+  virtual ~ColumnStatisticsDesc() throw();
   bool isTblLevel;
   std::string dbName;
   std::string tableName;
@@ -2927,27 +2869,15 @@ class ColumnStatisticsDesc {
 
   _ColumnStatisticsDesc__isset __isset;
 
-  void __set_isTblLevel(const bool val) {
-    isTblLevel = val;
-  }
+  void __set_isTblLevel(const bool val);
 
-  void __set_dbName(const std::string& val) {
-    dbName = val;
-  }
+  void __set_dbName(const std::string& val);
 
-  void __set_tableName(const std::string& val) {
-    tableName = val;
-  }
+  void __set_tableName(const std::string& val);
 
-  void __set_partName(const std::string& val) {
-    partName = val;
-    __isset.partName = true;
-  }
+  void __set_partName(const std::string& val);
 
-  void __set_lastAnalyzed(const int64_t val) {
-    lastAnalyzed = val;
-    __isset.lastAnalyzed = true;
-  }
+  void __set_lastAnalyzed(const int64_t val);
 
   bool operator == (const ColumnStatisticsDesc & rhs) const
   {
@@ -2976,6 +2906,7 @@ class ColumnStatisticsDesc {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ColumnStatisticsDesc& obj);
 };
 
 void swap(ColumnStatisticsDesc &a, ColumnStatisticsDesc &b);
@@ -2987,21 +2918,18 @@ class ColumnStatistics {
   static const char* ascii_fingerprint; // = "8A64D0A67FFD3A372726A320B3913D5A";
   static const uint8_t binary_fingerprint[16]; // = {0x8A,0x64,0xD0,0xA6,0x7F,0xFD,0x3A,0x37,0x27,0x26,0xA3,0x20,0xB3,0x91,0x3D,0x5A};
 
+  ColumnStatistics(const ColumnStatistics&);
+  ColumnStatistics& operator=(const ColumnStatistics&);
   ColumnStatistics() {
   }
 
-  virtual ~ColumnStatistics() throw() {}
-
+  virtual ~ColumnStatistics() throw();
   ColumnStatisticsDesc statsDesc;
   std::vector<ColumnStatisticsObj>  statsObj;
 
-  void __set_statsDesc(const ColumnStatisticsDesc& val) {
-    statsDesc = val;
-  }
+  void __set_statsDesc(const ColumnStatisticsDesc& val);
 
-  void __set_statsObj(const std::vector<ColumnStatisticsObj> & val) {
-    statsObj = val;
-  }
+  void __set_statsObj(const std::vector<ColumnStatisticsObj> & val);
 
   bool operator == (const ColumnStatistics & rhs) const
   {
@@ -3020,6 +2948,7 @@ class ColumnStatistics {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const ColumnStatistics& obj);
 };
 
 void swap(ColumnStatistics &a, ColumnStatistics &b);
@@ -3031,21 +2960,18 @@ class AggrStats {
   static const char* ascii_fingerprint; // = "1FC765A3AB2954591C14B0D946778213";
   static const uint8_t binary_fingerprint[16]; // = {0x1F,0xC7,0x65,0xA3,0xAB,0x29,0x54,0x59,0x1C,0x14,0xB0,0xD9,0x46,0x77,0x82,0x13};
 
+  AggrStats(const AggrStats&);
+  AggrStats& operator=(const AggrStats&);
   AggrStats() : partsFound(0) {
   }
 
-  virtual ~AggrStats() throw() {}
-
+  virtual ~AggrStats() throw();
   std::vector<ColumnStatisticsObj>  colStats;
   int64_t partsFound;
 
-  void __set_colStats(const std::vector<ColumnStatisticsObj> & val) {
-    colStats = val;
-  }
+  void __set_colStats(const std::vector<ColumnStatisticsObj> & val);
 
-  void __set_partsFound(const int64_t val) {
-    partsFound = val;
-  }
+  void __set_partsFound(const int64_t val);
 
   bool operator == (const AggrStats & rhs) const
   {
@@ -3064,6 +2990,7 @@ class AggrStats {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostream& operator<<(std::ostream& out, const AggrStats& obj);
 };
 
 void swap(AggrStats &a, AggrStats &b);
@@ -3075,16 +3002,15 @@ class SetPartitionsStatsRequest {
   static const char* ascii_fingerprint; // = "8BCBF2CE9E942D0FB7D8F4ED57D8DC27";
   static const uint8_t binary_fingerprint[16]; // = {0x8B,0xCB,0xF2,0xCE,0x9E,0x94,0x2D,0x0F,0xB7,0xD8,0xF4,0xED,0x57,0xD8,0xDC,0x27};
 
+  SetPartitionsStatsRequest(const SetPartitionsStatsRequest&);
+  SetPartitionsStatsRequest& operator=(const SetPartitionsStatsRequest&);
   SetPartitionsStatsRequest() {
   }
 
-  virtual ~SetPartitionsStatsRequest() throw() {}
-
+  virtual ~SetPartitionsStatsRequest() throw();
   std::vector<ColumnStatistics>  colStats;
 
-  void __set_colStats(const std::vector<ColumnStatistics> & val) {
-    colStats = val;
-  }
+  void __set_colStats(const std::vector<ColumnStatistics> & val);
 
   bool operator == (const SetPartitionsStatsRequest & rhs) const
   {
@@ -3101,14 +3027,15 @@ class SetPartitionsStatsRequest {
   uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
   uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
 
+  friend std::ostr

<TRUNCATED>

[05/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasReq.java
index c2aadaa..babe3cd 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetSchemasReq implements org.apache.thrift.TBase<TGetSchemasReq, TGetSchemasReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetSchemasReq implements org.apache.thrift.TBase<TGetSchemasReq, TGetSchemasReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetSchemasReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetSchemasReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -113,7 +117,7 @@ public class TGetSchemasReq implements org.apache.thrift.TBase<TGetSchemasReq, T
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME};
+  private static final _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -338,60 +342,60 @@ public class TGetSchemasReq implements org.apache.thrift.TBase<TGetSchemasReq, T
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_catalogName = true && (isSetCatalogName());
-    builder.append(present_catalogName);
+    list.add(present_catalogName);
     if (present_catalogName)
-      builder.append(catalogName);
+      list.add(catalogName);
 
     boolean present_schemaName = true && (isSetSchemaName());
-    builder.append(present_schemaName);
+    list.add(present_schemaName);
     if (present_schemaName)
-      builder.append(schemaName);
+      list.add(schemaName);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetSchemasReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetSchemasReq typedOther = (TGetSchemasReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(typedOther.isSetCatalogName());
+    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(other.isSetCatalogName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCatalogName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, typedOther.catalogName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, other.catalogName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(typedOther.isSetSchemaName());
+    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(other.isSetSchemaName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSchemaName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, typedOther.schemaName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, other.schemaName);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasResp.java
index ac1ea3e..68b5d78 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetSchemasResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetSchemasResp implements org.apache.thrift.TBase<TGetSchemasResp, TGetSchemasResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetSchemasResp implements org.apache.thrift.TBase<TGetSchemasResp, TGetSchemasResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetSchemasResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetSchemasResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetSchemasResp implements org.apache.thrift.TBase<TGetSchemasResp,
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetSchemasResp implements org.apache.thrift.TBase<TGetSchemasResp,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetSchemasResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetSchemasResp typedOther = (TGetSchemasResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesReq.java
index 6f2c713..57ed257 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTableTypesReq implements org.apache.thrift.TBase<TGetTableTypesReq, TGetTableTypesReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTableTypesReq implements org.apache.thrift.TBase<TGetTableTypesReq, TGetTableTypesReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTableTypesReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTableTypesReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TGetTableTypesReq implements org.apache.thrift.TBase<TGetTableTypes
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTableTypesReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTableTypesReq typedOther = (TGetTableTypesReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesResp.java
index 6f33fbc..0baeb80 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTableTypesResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTableTypesResp implements org.apache.thrift.TBase<TGetTableTypesResp, TGetTableTypesResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTableTypesResp implements org.apache.thrift.TBase<TGetTableTypesResp, TGetTableTypesResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTableTypesResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTableTypesResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetTableTypesResp implements org.apache.thrift.TBase<TGetTableType
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetTableTypesResp implements org.apache.thrift.TBase<TGetTableType
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTableTypesResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTableTypesResp typedOther = (TGetTableTypesResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesReq.java
index c973fcc..ed8cf35 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGetTablesReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGetTablesReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTablesReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTablesReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -123,7 +127,7 @@ public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGe
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME,_Fields.TABLE_NAME,_Fields.TABLE_TYPES};
+  private static final _Fields optionals[] = {_Fields.CATALOG_NAME,_Fields.SCHEMA_NAME,_Fields.TABLE_NAME,_Fields.TABLE_TYPES};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -169,10 +173,7 @@ public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGe
       this.tableName = other.tableName;
     }
     if (other.isSetTableTypes()) {
-      List<String> __this__tableTypes = new ArrayList<String>();
-      for (String other_element : other.tableTypes) {
-        __this__tableTypes.add(other_element);
-      }
+      List<String> __this__tableTypes = new ArrayList<String>(other.tableTypes);
       this.tableTypes = __this__tableTypes;
     }
   }
@@ -470,90 +471,90 @@ public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGe
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
     boolean present_catalogName = true && (isSetCatalogName());
-    builder.append(present_catalogName);
+    list.add(present_catalogName);
     if (present_catalogName)
-      builder.append(catalogName);
+      list.add(catalogName);
 
     boolean present_schemaName = true && (isSetSchemaName());
-    builder.append(present_schemaName);
+    list.add(present_schemaName);
     if (present_schemaName)
-      builder.append(schemaName);
+      list.add(schemaName);
 
     boolean present_tableName = true && (isSetTableName());
-    builder.append(present_tableName);
+    list.add(present_tableName);
     if (present_tableName)
-      builder.append(tableName);
+      list.add(tableName);
 
     boolean present_tableTypes = true && (isSetTableTypes());
-    builder.append(present_tableTypes);
+    list.add(present_tableTypes);
     if (present_tableTypes)
-      builder.append(tableTypes);
+      list.add(tableTypes);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTablesReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTablesReq typedOther = (TGetTablesReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(typedOther.isSetCatalogName());
+    lastComparison = Boolean.valueOf(isSetCatalogName()).compareTo(other.isSetCatalogName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetCatalogName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, typedOther.catalogName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catalogName, other.catalogName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(typedOther.isSetSchemaName());
+    lastComparison = Boolean.valueOf(isSetSchemaName()).compareTo(other.isSetSchemaName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSchemaName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, typedOther.schemaName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.schemaName, other.schemaName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(typedOther.isSetTableName());
+    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableName()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, typedOther.tableName);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetTableTypes()).compareTo(typedOther.isSetTableTypes());
+    lastComparison = Boolean.valueOf(isSetTableTypes()).compareTo(other.isSetTableTypes());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetTableTypes()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableTypes, typedOther.tableTypes);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableTypes, other.tableTypes);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -713,11 +714,11 @@ public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGe
               {
                 org.apache.thrift.protocol.TList _list172 = iprot.readListBegin();
                 struct.tableTypes = new ArrayList<String>(_list172.size);
-                for (int _i173 = 0; _i173 < _list172.size; ++_i173)
+                String _elem173;
+                for (int _i174 = 0; _i174 < _list172.size; ++_i174)
                 {
-                  String _elem174; // optional
-                  _elem174 = iprot.readString();
-                  struct.tableTypes.add(_elem174);
+                  _elem173 = iprot.readString();
+                  struct.tableTypes.add(_elem173);
                 }
                 iprot.readListEnd();
               }
@@ -854,11 +855,11 @@ public class TGetTablesReq implements org.apache.thrift.TBase<TGetTablesReq, TGe
         {
           org.apache.thrift.protocol.TList _list177 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
           struct.tableTypes = new ArrayList<String>(_list177.size);
-          for (int _i178 = 0; _i178 < _list177.size; ++_i178)
+          String _elem178;
+          for (int _i179 = 0; _i179 < _list177.size; ++_i179)
           {
-            String _elem179; // optional
-            _elem179 = iprot.readString();
-            struct.tableTypes.add(_elem179);
+            _elem178 = iprot.readString();
+            struct.tableTypes.add(_elem178);
           }
         }
         struct.setTableTypesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesResp.java
index d526f44..c61bfb1 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTablesResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTablesResp implements org.apache.thrift.TBase<TGetTablesResp, TGetTablesResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTablesResp implements org.apache.thrift.TBase<TGetTablesResp, TGetTablesResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTablesResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTablesResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetTablesResp implements org.apache.thrift.TBase<TGetTablesResp, T
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetTablesResp implements org.apache.thrift.TBase<TGetTablesResp, T
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTablesResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTablesResp typedOther = (TGetTablesResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoReq.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoReq.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoReq.java
index d40115e..aef8909 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoReq.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoReq.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTypeInfoReq implements org.apache.thrift.TBase<TGetTypeInfoReq, TGetTypeInfoReq._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTypeInfoReq implements org.apache.thrift.TBase<TGetTypeInfoReq, TGetTypeInfoReq._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTypeInfoReq> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTypeInfoReq");
 
   private static final org.apache.thrift.protocol.TField SESSION_HANDLE_FIELD_DESC = new org.apache.thrift.protocol.TField("sessionHandle", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -225,30 +229,30 @@ public class TGetTypeInfoReq implements org.apache.thrift.TBase<TGetTypeInfoReq,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_sessionHandle = true && (isSetSessionHandle());
-    builder.append(present_sessionHandle);
+    list.add(present_sessionHandle);
     if (present_sessionHandle)
-      builder.append(sessionHandle);
+      list.add(sessionHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTypeInfoReq other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTypeInfoReq typedOther = (TGetTypeInfoReq)other;
 
-    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(typedOther.isSetSessionHandle());
+    lastComparison = Boolean.valueOf(isSetSessionHandle()).compareTo(other.isSetSessionHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSessionHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, typedOther.sessionHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.sessionHandle, other.sessionHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoResp.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoResp.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoResp.java
index 59be1a3..2221002 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoResp.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TGetTypeInfoResp.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TGetTypeInfoResp implements org.apache.thrift.TBase<TGetTypeInfoResp, TGetTypeInfoResp._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TGetTypeInfoResp implements org.apache.thrift.TBase<TGetTypeInfoResp, TGetTypeInfoResp._Fields>, java.io.Serializable, Cloneable, Comparable<TGetTypeInfoResp> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TGetTypeInfoResp");
 
   private static final org.apache.thrift.protocol.TField STATUS_FIELD_DESC = new org.apache.thrift.protocol.TField("status", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -108,7 +112,7 @@ public class TGetTypeInfoResp implements org.apache.thrift.TBase<TGetTypeInfoRes
   }
 
   // isset id assignments
-  private _Fields optionals[] = {_Fields.OPERATION_HANDLE};
+  private static final _Fields optionals[] = {_Fields.OPERATION_HANDLE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -282,45 +286,45 @@ public class TGetTypeInfoResp implements org.apache.thrift.TBase<TGetTypeInfoRes
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_status = true && (isSetStatus());
-    builder.append(present_status);
+    list.add(present_status);
     if (present_status)
-      builder.append(status);
+      list.add(status);
 
     boolean present_operationHandle = true && (isSetOperationHandle());
-    builder.append(present_operationHandle);
+    list.add(present_operationHandle);
     if (present_operationHandle)
-      builder.append(operationHandle);
+      list.add(operationHandle);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TGetTypeInfoResp other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TGetTypeInfoResp typedOther = (TGetTypeInfoResp)other;
 
-    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(typedOther.isSetStatus());
+    lastComparison = Boolean.valueOf(isSetStatus()).compareTo(other.isSetStatus());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetStatus()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, typedOther.status);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.status, other.status);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(typedOther.isSetOperationHandle());
+    lastComparison = Boolean.valueOf(isSetOperationHandle()).compareTo(other.isSetOperationHandle());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetOperationHandle()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, typedOther.operationHandle);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.operationHandle, other.operationHandle);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/THandleIdentifier.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/THandleIdentifier.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/THandleIdentifier.java
index 368273c..f6a81f9 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/THandleIdentifier.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/THandleIdentifier.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentifier, THandleIdentifier._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentifier, THandleIdentifier._Fields>, java.io.Serializable, Cloneable, Comparable<THandleIdentifier> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("THandleIdentifier");
 
   private static final org.apache.thrift.protocol.TField GUID_FIELD_DESC = new org.apache.thrift.protocol.TField("guid", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -127,8 +131,8 @@ public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentif
     ByteBuffer secret)
   {
     this();
-    this.guid = guid;
-    this.secret = secret;
+    this.guid = org.apache.thrift.TBaseHelper.copyBinary(guid);
+    this.secret = org.apache.thrift.TBaseHelper.copyBinary(secret);
   }
 
   /**
@@ -137,11 +141,9 @@ public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentif
   public THandleIdentifier(THandleIdentifier other) {
     if (other.isSetGuid()) {
       this.guid = org.apache.thrift.TBaseHelper.copyBinary(other.guid);
-;
     }
     if (other.isSetSecret()) {
       this.secret = org.apache.thrift.TBaseHelper.copyBinary(other.secret);
-;
     }
   }
 
@@ -161,15 +163,15 @@ public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentif
   }
 
   public ByteBuffer bufferForGuid() {
-    return guid;
+    return org.apache.thrift.TBaseHelper.copyBinary(guid);
   }
 
   public void setGuid(byte[] guid) {
-    setGuid(guid == null ? (ByteBuffer)null : ByteBuffer.wrap(guid));
+    this.guid = guid == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(guid, guid.length));
   }
 
   public void setGuid(ByteBuffer guid) {
-    this.guid = guid;
+    this.guid = org.apache.thrift.TBaseHelper.copyBinary(guid);
   }
 
   public void unsetGuid() {
@@ -193,15 +195,15 @@ public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentif
   }
 
   public ByteBuffer bufferForSecret() {
-    return secret;
+    return org.apache.thrift.TBaseHelper.copyBinary(secret);
   }
 
   public void setSecret(byte[] secret) {
-    setSecret(secret == null ? (ByteBuffer)null : ByteBuffer.wrap(secret));
+    this.secret = secret == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(secret, secret.length));
   }
 
   public void setSecret(ByteBuffer secret) {
-    this.secret = secret;
+    this.secret = org.apache.thrift.TBaseHelper.copyBinary(secret);
   }
 
   public void unsetSecret() {
@@ -303,45 +305,45 @@ public class THandleIdentifier implements org.apache.thrift.TBase<THandleIdentif
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_guid = true && (isSetGuid());
-    builder.append(present_guid);
+    list.add(present_guid);
     if (present_guid)
-      builder.append(guid);
+      list.add(guid);
 
     boolean present_secret = true && (isSetSecret());
-    builder.append(present_secret);
+    list.add(present_secret);
     if (present_secret)
-      builder.append(secret);
+      list.add(secret);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(THandleIdentifier other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    THandleIdentifier typedOther = (THandleIdentifier)other;
 
-    lastComparison = Boolean.valueOf(isSetGuid()).compareTo(typedOther.isSetGuid());
+    lastComparison = Boolean.valueOf(isSetGuid()).compareTo(other.isSetGuid());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetGuid()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.guid, typedOther.guid);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.guid, other.guid);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetSecret()).compareTo(typedOther.isSetSecret());
+    lastComparison = Boolean.valueOf(isSetSecret()).compareTo(other.isSetSecret());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetSecret()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.secret, typedOther.secret);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.secret, other.secret);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Column.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Column.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Column.java
index c836630..c23a619 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Column.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Column.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Column._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Column._Fields>, java.io.Serializable, Cloneable, Comparable<TI16Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI16Column");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
    */
   public TI16Column(TI16Column other) {
     if (other.isSetValues()) {
-      List<Short> __this__values = new ArrayList<Short>();
-      for (Short other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Short> __this__values = new ArrayList<Short>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI16Column other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI16Column typedOther = (TI16Column)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
               {
                 org.apache.thrift.protocol.TList _list70 = iprot.readListBegin();
                 struct.values = new ArrayList<Short>(_list70.size);
-                for (int _i71 = 0; _i71 < _list70.size; ++_i71)
+                short _elem71;
+                for (int _i72 = 0; _i72 < _list70.size; ++_i72)
                 {
-                  short _elem72; // optional
-                  _elem72 = iprot.readI16();
-                  struct.values.add(_elem72);
+                  _elem71 = iprot.readI16();
+                  struct.values.add(_elem71);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TI16Column implements org.apache.thrift.TBase<TI16Column, TI16Colum
       {
         org.apache.thrift.protocol.TList _list75 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I16, iprot.readI32());
         struct.values = new ArrayList<Short>(_list75.size);
-        for (int _i76 = 0; _i76 < _list75.size; ++_i76)
+        short _elem76;
+        for (int _i77 = 0; _i77 < _list75.size; ++_i77)
         {
-          short _elem77; // optional
-          _elem77 = iprot.readI16();
-          struct.values.add(_elem77);
+          _elem76 = iprot.readI16();
+          struct.values.add(_elem76);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Value.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Value.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Value.java
index bb5ae96..c8c262f 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Value.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI16Value.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI16Value implements org.apache.thrift.TBase<TI16Value, TI16Value._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI16Value implements org.apache.thrift.TBase<TI16Value, TI16Value._Fields>, java.io.Serializable, Cloneable, Comparable<TI16Value> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI16Value");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.I16, (short)1);
@@ -105,7 +109,7 @@ public class TI16Value implements org.apache.thrift.TBase<TI16Value, TI16Value._
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TI16Value implements org.apache.thrift.TBase<TI16Value, TI16Value._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI16Value other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI16Value typedOther = (TI16Value)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Column.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Column.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Column.java
index 6c6c5f3..90e2136 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Column.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Column.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Column._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Column._Fields>, java.io.Serializable, Cloneable, Comparable<TI32Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI32Column");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
    */
   public TI32Column(TI32Column other) {
     if (other.isSetValues()) {
-      List<Integer> __this__values = new ArrayList<Integer>();
-      for (Integer other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Integer> __this__values = new ArrayList<Integer>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI32Column other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI32Column typedOther = (TI32Column)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
               {
                 org.apache.thrift.protocol.TList _list78 = iprot.readListBegin();
                 struct.values = new ArrayList<Integer>(_list78.size);
-                for (int _i79 = 0; _i79 < _list78.size; ++_i79)
+                int _elem79;
+                for (int _i80 = 0; _i80 < _list78.size; ++_i80)
                 {
-                  int _elem80; // optional
-                  _elem80 = iprot.readI32();
-                  struct.values.add(_elem80);
+                  _elem79 = iprot.readI32();
+                  struct.values.add(_elem79);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TI32Column implements org.apache.thrift.TBase<TI32Column, TI32Colum
       {
         org.apache.thrift.protocol.TList _list83 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I32, iprot.readI32());
         struct.values = new ArrayList<Integer>(_list83.size);
-        for (int _i84 = 0; _i84 < _list83.size; ++_i84)
+        int _elem84;
+        for (int _i85 = 0; _i85 < _list83.size; ++_i85)
         {
-          int _elem85; // optional
-          _elem85 = iprot.readI32();
-          struct.values.add(_elem85);
+          _elem84 = iprot.readI32();
+          struct.values.add(_elem84);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Value.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Value.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Value.java
index 059408b..02ffc1b 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Value.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI32Value.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI32Value implements org.apache.thrift.TBase<TI32Value, TI32Value._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI32Value implements org.apache.thrift.TBase<TI32Value, TI32Value._Fields>, java.io.Serializable, Cloneable, Comparable<TI32Value> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI32Value");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -105,7 +109,7 @@ public class TI32Value implements org.apache.thrift.TBase<TI32Value, TI32Value._
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TI32Value implements org.apache.thrift.TBase<TI32Value, TI32Value._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI32Value other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI32Value typedOther = (TI32Value)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Column.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Column.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Column.java
index cc383ed..7628942 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Column.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Column.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Column._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Column._Fields>, java.io.Serializable, Cloneable, Comparable<TI64Column> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI64Column");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,15 +141,11 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
    */
   public TI64Column(TI64Column other) {
     if (other.isSetValues()) {
-      List<Long> __this__values = new ArrayList<Long>();
-      for (Long other_element : other.values) {
-        __this__values.add(other_element);
-      }
+      List<Long> __this__values = new ArrayList<Long>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -203,15 +203,15 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -313,45 +313,45 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI64Column other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI64Column typedOther = (TI64Column)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -447,11 +447,11 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
               {
                 org.apache.thrift.protocol.TList _list86 = iprot.readListBegin();
                 struct.values = new ArrayList<Long>(_list86.size);
-                for (int _i87 = 0; _i87 < _list86.size; ++_i87)
+                long _elem87;
+                for (int _i88 = 0; _i88 < _list86.size; ++_i88)
                 {
-                  long _elem88; // optional
-                  _elem88 = iprot.readI64();
-                  struct.values.add(_elem88);
+                  _elem87 = iprot.readI64();
+                  struct.values.add(_elem87);
                 }
                 iprot.readListEnd();
               }
@@ -531,11 +531,11 @@ public class TI64Column implements org.apache.thrift.TBase<TI64Column, TI64Colum
       {
         org.apache.thrift.protocol.TList _list91 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.I64, iprot.readI32());
         struct.values = new ArrayList<Long>(_list91.size);
-        for (int _i92 = 0; _i92 < _list91.size; ++_i92)
+        long _elem92;
+        for (int _i93 = 0; _i93 < _list91.size; ++_i93)
         {
-          long _elem93; // optional
-          _elem93 = iprot.readI64();
-          struct.values.add(_elem93);
+          _elem92 = iprot.readI64();
+          struct.values.add(_elem92);
         }
       }
       struct.setValuesIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Value.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Value.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Value.java
index 9a941cc..7fd8c23 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Value.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TI64Value.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TI64Value implements org.apache.thrift.TBase<TI64Value, TI64Value._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TI64Value implements org.apache.thrift.TBase<TI64Value, TI64Value._Fields>, java.io.Serializable, Cloneable, Comparable<TI64Value> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TI64Value");
 
   private static final org.apache.thrift.protocol.TField VALUE_FIELD_DESC = new org.apache.thrift.protocol.TField("value", org.apache.thrift.protocol.TType.I64, (short)1);
@@ -105,7 +109,7 @@ public class TI64Value implements org.apache.thrift.TBase<TI64Value, TI64Value._
   // isset id assignments
   private static final int __VALUE_ISSET_ID = 0;
   private byte __isset_bitfield = 0;
-  private _Fields optionals[] = {_Fields.VALUE};
+  private static final _Fields optionals[] = {_Fields.VALUE};
   public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
   static {
     Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
@@ -220,30 +224,30 @@ public class TI64Value implements org.apache.thrift.TBase<TI64Value, TI64Value._
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_value = true && (isSetValue());
-    builder.append(present_value);
+    list.add(present_value);
     if (present_value)
-      builder.append(value);
+      list.add(value);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TI64Value other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TI64Value typedOther = (TI64Value)other;
 
-    lastComparison = Boolean.valueOf(isSetValue()).compareTo(typedOther.isSetValue());
+    lastComparison = Boolean.valueOf(isSetValue()).compareTo(other.isSetValue());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValue()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, typedOther.value);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.value, other.value);
       if (lastComparison != 0) {
         return lastComparison;
       }


[10/48] hive git commit: HIVE-9152 - Dynamic Partition Pruning [Spark Branch] (Chao Sun, reviewed by Xuefu Zhang and Chengxiang Li)

Posted by su...@apache.org.
http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/ThriftHive.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/ThriftHive.java b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/ThriftHive.java
index 1c44789..e4ecd28 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/ThriftHive.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/service/ThriftHive.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hadoop.hive.service;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,9 +29,12 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
 public class ThriftHive {
 
   public interface Iface extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.Iface {
@@ -57,23 +61,23 @@ public class ThriftHive {
 
   public interface AsyncIface extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore .AsyncIface {
 
-    public void execute(String query, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.execute_call> resultHandler) throws org.apache.thrift.TException;
+    public void execute(String query, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void fetchOne(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.fetchOne_call> resultHandler) throws org.apache.thrift.TException;
+    public void fetchOne(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void fetchN(int numRows, org.apache.thrift.async.AsyncMethodCallback<AsyncClient.fetchN_call> resultHandler) throws org.apache.thrift.TException;
+    public void fetchN(int numRows, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void fetchAll(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.fetchAll_call> resultHandler) throws org.apache.thrift.TException;
+    public void fetchAll(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void getSchema(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getSchema_call> resultHandler) throws org.apache.thrift.TException;
+    public void getSchema(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void getThriftSchema(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getThriftSchema_call> resultHandler) throws org.apache.thrift.TException;
+    public void getThriftSchema(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void getClusterStatus(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getClusterStatus_call> resultHandler) throws org.apache.thrift.TException;
+    public void getClusterStatus(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void getQueryPlan(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.getQueryPlan_call> resultHandler) throws org.apache.thrift.TException;
+    public void getQueryPlan(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
-    public void clean(org.apache.thrift.async.AsyncMethodCallback<AsyncClient.clean_call> resultHandler) throws org.apache.thrift.TException;
+    public void clean(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
   }
 
@@ -333,7 +337,7 @@ public class ThriftHive {
       super(protocolFactory, clientManager, transport);
     }
 
-    public void execute(String query, org.apache.thrift.async.AsyncMethodCallback<execute_call> resultHandler) throws org.apache.thrift.TException {
+    public void execute(String query, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       execute_call method_call = new execute_call(query, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -342,7 +346,7 @@ public class ThriftHive {
 
     public static class execute_call extends org.apache.thrift.async.TAsyncMethodCall {
       private String query;
-      public execute_call(String query, org.apache.thrift.async.AsyncMethodCallback<execute_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public execute_call(String query, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.query = query;
       }
@@ -365,7 +369,7 @@ public class ThriftHive {
       }
     }
 
-    public void fetchOne(org.apache.thrift.async.AsyncMethodCallback<fetchOne_call> resultHandler) throws org.apache.thrift.TException {
+    public void fetchOne(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       fetchOne_call method_call = new fetchOne_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -373,7 +377,7 @@ public class ThriftHive {
     }
 
     public static class fetchOne_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public fetchOne_call(org.apache.thrift.async.AsyncMethodCallback<fetchOne_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public fetchOne_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -394,7 +398,7 @@ public class ThriftHive {
       }
     }
 
-    public void fetchN(int numRows, org.apache.thrift.async.AsyncMethodCallback<fetchN_call> resultHandler) throws org.apache.thrift.TException {
+    public void fetchN(int numRows, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       fetchN_call method_call = new fetchN_call(numRows, resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -403,7 +407,7 @@ public class ThriftHive {
 
     public static class fetchN_call extends org.apache.thrift.async.TAsyncMethodCall {
       private int numRows;
-      public fetchN_call(int numRows, org.apache.thrift.async.AsyncMethodCallback<fetchN_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public fetchN_call(int numRows, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
         this.numRows = numRows;
       }
@@ -426,7 +430,7 @@ public class ThriftHive {
       }
     }
 
-    public void fetchAll(org.apache.thrift.async.AsyncMethodCallback<fetchAll_call> resultHandler) throws org.apache.thrift.TException {
+    public void fetchAll(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       fetchAll_call method_call = new fetchAll_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -434,7 +438,7 @@ public class ThriftHive {
     }
 
     public static class fetchAll_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public fetchAll_call(org.apache.thrift.async.AsyncMethodCallback<fetchAll_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public fetchAll_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -455,7 +459,7 @@ public class ThriftHive {
       }
     }
 
-    public void getSchema(org.apache.thrift.async.AsyncMethodCallback<getSchema_call> resultHandler) throws org.apache.thrift.TException {
+    public void getSchema(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       getSchema_call method_call = new getSchema_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -463,7 +467,7 @@ public class ThriftHive {
     }
 
     public static class getSchema_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getSchema_call(org.apache.thrift.async.AsyncMethodCallback<getSchema_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public getSchema_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -484,7 +488,7 @@ public class ThriftHive {
       }
     }
 
-    public void getThriftSchema(org.apache.thrift.async.AsyncMethodCallback<getThriftSchema_call> resultHandler) throws org.apache.thrift.TException {
+    public void getThriftSchema(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       getThriftSchema_call method_call = new getThriftSchema_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -492,7 +496,7 @@ public class ThriftHive {
     }
 
     public static class getThriftSchema_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getThriftSchema_call(org.apache.thrift.async.AsyncMethodCallback<getThriftSchema_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public getThriftSchema_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -513,7 +517,7 @@ public class ThriftHive {
       }
     }
 
-    public void getClusterStatus(org.apache.thrift.async.AsyncMethodCallback<getClusterStatus_call> resultHandler) throws org.apache.thrift.TException {
+    public void getClusterStatus(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       getClusterStatus_call method_call = new getClusterStatus_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -521,7 +525,7 @@ public class ThriftHive {
     }
 
     public static class getClusterStatus_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getClusterStatus_call(org.apache.thrift.async.AsyncMethodCallback<getClusterStatus_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public getClusterStatus_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -542,7 +546,7 @@ public class ThriftHive {
       }
     }
 
-    public void getQueryPlan(org.apache.thrift.async.AsyncMethodCallback<getQueryPlan_call> resultHandler) throws org.apache.thrift.TException {
+    public void getQueryPlan(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       getQueryPlan_call method_call = new getQueryPlan_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -550,7 +554,7 @@ public class ThriftHive {
     }
 
     public static class getQueryPlan_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public getQueryPlan_call(org.apache.thrift.async.AsyncMethodCallback<getQueryPlan_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public getQueryPlan_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -571,7 +575,7 @@ public class ThriftHive {
       }
     }
 
-    public void clean(org.apache.thrift.async.AsyncMethodCallback<clean_call> resultHandler) throws org.apache.thrift.TException {
+    public void clean(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       clean_call method_call = new clean_call(resultHandler, this, ___protocolFactory, ___transport);
       this.___currentMethod = method_call;
@@ -579,7 +583,7 @@ public class ThriftHive {
     }
 
     public static class clean_call extends org.apache.thrift.async.TAsyncMethodCall {
-      public clean_call(org.apache.thrift.async.AsyncMethodCallback<clean_call> resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+      public clean_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
         super(client, protocolFactory, transport, resultHandler, false);
       }
 
@@ -839,7 +843,537 @@ public class ThriftHive {
 
   }
 
-  public static class execute_args implements org.apache.thrift.TBase<execute_args, execute_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class AsyncProcessor<I extends AsyncIface> extends org.apache.hadoop.hive.metastore.api.ThriftHiveMetastore.AsyncProcessor<I> {
+    private static final Logger LOGGER = LoggerFactory.getLogger(AsyncProcessor.class.getName());
+    public AsyncProcessor(I iface) {
+      super(iface, getProcessMap(new HashMap<String, org.apache.thrift.AsyncProcessFunction<I, ? extends org.apache.thrift.TBase, ?>>()));
+    }
+
+    protected AsyncProcessor(I iface, Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase, ?>> processMap) {
+      super(iface, getProcessMap(processMap));
+    }
+
+    private static <I extends AsyncIface> Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase,?>> getProcessMap(Map<String,  org.apache.thrift.AsyncProcessFunction<I, ? extends  org.apache.thrift.TBase, ?>> processMap) {
+      processMap.put("execute", new execute());
+      processMap.put("fetchOne", new fetchOne());
+      processMap.put("fetchN", new fetchN());
+      processMap.put("fetchAll", new fetchAll());
+      processMap.put("getSchema", new getSchema());
+      processMap.put("getThriftSchema", new getThriftSchema());
+      processMap.put("getClusterStatus", new getClusterStatus());
+      processMap.put("getQueryPlan", new getQueryPlan());
+      processMap.put("clean", new clean());
+      return processMap;
+    }
+
+    public static class execute<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, execute_args, Void> {
+      public execute() {
+        super("execute");
+      }
+
+      public execute_args getEmptyArgsInstance() {
+        return new execute_args();
+      }
+
+      public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<Void>() { 
+          public void onComplete(Void o) {
+            execute_result result = new execute_result();
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            execute_result result = new execute_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, execute_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException {
+        iface.execute(args.query,resultHandler);
+      }
+    }
+
+    public static class fetchOne<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, fetchOne_args, String> {
+      public fetchOne() {
+        super("fetchOne");
+      }
+
+      public fetchOne_args getEmptyArgsInstance() {
+        return new fetchOne_args();
+      }
+
+      public AsyncMethodCallback<String> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<String>() { 
+          public void onComplete(String o) {
+            fetchOne_result result = new fetchOne_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            fetchOne_result result = new fetchOne_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, fetchOne_args args, org.apache.thrift.async.AsyncMethodCallback<String> resultHandler) throws TException {
+        iface.fetchOne(resultHandler);
+      }
+    }
+
+    public static class fetchN<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, fetchN_args, List<String>> {
+      public fetchN() {
+        super("fetchN");
+      }
+
+      public fetchN_args getEmptyArgsInstance() {
+        return new fetchN_args();
+      }
+
+      public AsyncMethodCallback<List<String>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<List<String>>() { 
+          public void onComplete(List<String> o) {
+            fetchN_result result = new fetchN_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            fetchN_result result = new fetchN_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, fetchN_args args, org.apache.thrift.async.AsyncMethodCallback<List<String>> resultHandler) throws TException {
+        iface.fetchN(args.numRows,resultHandler);
+      }
+    }
+
+    public static class fetchAll<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, fetchAll_args, List<String>> {
+      public fetchAll() {
+        super("fetchAll");
+      }
+
+      public fetchAll_args getEmptyArgsInstance() {
+        return new fetchAll_args();
+      }
+
+      public AsyncMethodCallback<List<String>> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<List<String>>() { 
+          public void onComplete(List<String> o) {
+            fetchAll_result result = new fetchAll_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            fetchAll_result result = new fetchAll_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, fetchAll_args args, org.apache.thrift.async.AsyncMethodCallback<List<String>> resultHandler) throws TException {
+        iface.fetchAll(resultHandler);
+      }
+    }
+
+    public static class getSchema<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getSchema_args, org.apache.hadoop.hive.metastore.api.Schema> {
+      public getSchema() {
+        super("getSchema");
+      }
+
+      public getSchema_args getEmptyArgsInstance() {
+        return new getSchema_args();
+      }
+
+      public AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema>() { 
+          public void onComplete(org.apache.hadoop.hive.metastore.api.Schema o) {
+            getSchema_result result = new getSchema_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            getSchema_result result = new getSchema_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, getSchema_args args, org.apache.thrift.async.AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema> resultHandler) throws TException {
+        iface.getSchema(resultHandler);
+      }
+    }
+
+    public static class getThriftSchema<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getThriftSchema_args, org.apache.hadoop.hive.metastore.api.Schema> {
+      public getThriftSchema() {
+        super("getThriftSchema");
+      }
+
+      public getThriftSchema_args getEmptyArgsInstance() {
+        return new getThriftSchema_args();
+      }
+
+      public AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema>() { 
+          public void onComplete(org.apache.hadoop.hive.metastore.api.Schema o) {
+            getThriftSchema_result result = new getThriftSchema_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            getThriftSchema_result result = new getThriftSchema_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, getThriftSchema_args args, org.apache.thrift.async.AsyncMethodCallback<org.apache.hadoop.hive.metastore.api.Schema> resultHandler) throws TException {
+        iface.getThriftSchema(resultHandler);
+      }
+    }
+
+    public static class getClusterStatus<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getClusterStatus_args, HiveClusterStatus> {
+      public getClusterStatus() {
+        super("getClusterStatus");
+      }
+
+      public getClusterStatus_args getEmptyArgsInstance() {
+        return new getClusterStatus_args();
+      }
+
+      public AsyncMethodCallback<HiveClusterStatus> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<HiveClusterStatus>() { 
+          public void onComplete(HiveClusterStatus o) {
+            getClusterStatus_result result = new getClusterStatus_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            getClusterStatus_result result = new getClusterStatus_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, getClusterStatus_args args, org.apache.thrift.async.AsyncMethodCallback<HiveClusterStatus> resultHandler) throws TException {
+        iface.getClusterStatus(resultHandler);
+      }
+    }
+
+    public static class getQueryPlan<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, getQueryPlan_args, org.apache.hadoop.hive.ql.plan.api.QueryPlan> {
+      public getQueryPlan() {
+        super("getQueryPlan");
+      }
+
+      public getQueryPlan_args getEmptyArgsInstance() {
+        return new getQueryPlan_args();
+      }
+
+      public AsyncMethodCallback<org.apache.hadoop.hive.ql.plan.api.QueryPlan> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<org.apache.hadoop.hive.ql.plan.api.QueryPlan>() { 
+          public void onComplete(org.apache.hadoop.hive.ql.plan.api.QueryPlan o) {
+            getQueryPlan_result result = new getQueryPlan_result();
+            result.success = o;
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            getQueryPlan_result result = new getQueryPlan_result();
+            if (e instanceof HiveServerException) {
+                        result.ex = (HiveServerException) e;
+                        result.setExIsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, getQueryPlan_args args, org.apache.thrift.async.AsyncMethodCallback<org.apache.hadoop.hive.ql.plan.api.QueryPlan> resultHandler) throws TException {
+        iface.getQueryPlan(resultHandler);
+      }
+    }
+
+    public static class clean<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, clean_args, Void> {
+      public clean() {
+        super("clean");
+      }
+
+      public clean_args getEmptyArgsInstance() {
+        return new clean_args();
+      }
+
+      public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<Void>() { 
+          public void onComplete(Void o) {
+            clean_result result = new clean_result();
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            clean_result result = new clean_result();
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, clean_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException {
+        iface.clean(resultHandler);
+      }
+    }
+
+  }
+
+  public static class execute_args implements org.apache.thrift.TBase<execute_args, execute_args._Fields>, java.io.Serializable, Cloneable, Comparable<execute_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("execute_args");
 
     private static final org.apache.thrift.protocol.TField QUERY_FIELD_DESC = new org.apache.thrift.protocol.TField("query", org.apache.thrift.protocol.TType.STRING, (short)1);
@@ -1033,30 +1567,30 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_query = true && (isSetQuery());
-      builder.append(present_query);
+      list.add(present_query);
       if (present_query)
-        builder.append(query);
+        list.add(query);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(execute_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      execute_args typedOther = (execute_args)other;
 
-      lastComparison = Boolean.valueOf(isSetQuery()).compareTo(typedOther.isSetQuery());
+      lastComparison = Boolean.valueOf(isSetQuery()).compareTo(other.isSetQuery());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetQuery()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.query, typedOther.query);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.query, other.query);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -1197,7 +1731,7 @@ public class ThriftHive {
 
   }
 
-  public static class execute_result implements org.apache.thrift.TBase<execute_result, execute_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class execute_result implements org.apache.thrift.TBase<execute_result, execute_result._Fields>, java.io.Serializable, Cloneable, Comparable<execute_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("execute_result");
 
     private static final org.apache.thrift.protocol.TField EX_FIELD_DESC = new org.apache.thrift.protocol.TField("ex", org.apache.thrift.protocol.TType.STRUCT, (short)1);
@@ -1391,30 +1925,30 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(execute_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      execute_result typedOther = (execute_result)other;
 
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -1557,7 +2091,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchOne_args implements org.apache.thrift.TBase<fetchOne_args, fetchOne_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchOne_args implements org.apache.thrift.TBase<fetchOne_args, fetchOne_args._Fields>, java.io.Serializable, Cloneable, Comparable<fetchOne_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchOne_args");
 
 
@@ -1687,18 +2221,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchOne_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchOne_args typedOther = (fetchOne_args)other;
 
       return 0;
     }
@@ -1803,7 +2337,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchOne_result implements org.apache.thrift.TBase<fetchOne_result, fetchOne_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchOne_result implements org.apache.thrift.TBase<fetchOne_result, fetchOne_result._Fields>, java.io.Serializable, Cloneable, Comparable<fetchOne_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchOne_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRING, (short)0);
@@ -2055,45 +2589,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchOne_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchOne_result typedOther = (fetchOne_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -2267,7 +2801,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchN_args implements org.apache.thrift.TBase<fetchN_args, fetchN_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchN_args implements org.apache.thrift.TBase<fetchN_args, fetchN_args._Fields>, java.io.Serializable, Cloneable, Comparable<fetchN_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchN_args");
 
     private static final org.apache.thrift.protocol.TField NUM_ROWS_FIELD_DESC = new org.apache.thrift.protocol.TField("numRows", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -2463,30 +2997,30 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_numRows = true;
-      builder.append(present_numRows);
+      list.add(present_numRows);
       if (present_numRows)
-        builder.append(numRows);
+        list.add(numRows);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchN_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchN_args typedOther = (fetchN_args)other;
 
-      lastComparison = Boolean.valueOf(isSetNumRows()).compareTo(typedOther.isSetNumRows());
+      lastComparison = Boolean.valueOf(isSetNumRows()).compareTo(other.isSetNumRows());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetNumRows()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numRows, typedOther.numRows);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.numRows, other.numRows);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -2623,7 +3157,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchN_result implements org.apache.thrift.TBase<fetchN_result, fetchN_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchN_result implements org.apache.thrift.TBase<fetchN_result, fetchN_result._Fields>, java.io.Serializable, Cloneable, Comparable<fetchN_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchN_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0);
@@ -2729,10 +3263,7 @@ public class ThriftHive {
      */
     public fetchN_result(fetchN_result other) {
       if (other.isSetSuccess()) {
-        List<String> __this__success = new ArrayList<String>();
-        for (String other_element : other.success) {
-          __this__success.add(other_element);
-        }
+        List<String> __this__success = new ArrayList<String>(other.success);
         this.success = __this__success;
       }
       if (other.isSetEx()) {
@@ -2895,45 +3426,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchN_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchN_result typedOther = (fetchN_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -3021,11 +3552,11 @@ public class ThriftHive {
                 {
                   org.apache.thrift.protocol.TList _list0 = iprot.readListBegin();
                   struct.success = new ArrayList<String>(_list0.size);
-                  for (int _i1 = 0; _i1 < _list0.size; ++_i1)
+                  String _elem1;
+                  for (int _i2 = 0; _i2 < _list0.size; ++_i2)
                   {
-                    String _elem2; // optional
-                    _elem2 = iprot.readString();
-                    struct.success.add(_elem2);
+                    _elem1 = iprot.readString();
+                    struct.success.add(_elem1);
                   }
                   iprot.readListEnd();
                 }
@@ -3120,11 +3651,11 @@ public class ThriftHive {
           {
             org.apache.thrift.protocol.TList _list5 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
             struct.success = new ArrayList<String>(_list5.size);
-            for (int _i6 = 0; _i6 < _list5.size; ++_i6)
+            String _elem6;
+            for (int _i7 = 0; _i7 < _list5.size; ++_i7)
             {
-              String _elem7; // optional
-              _elem7 = iprot.readString();
-              struct.success.add(_elem7);
+              _elem6 = iprot.readString();
+              struct.success.add(_elem6);
             }
           }
           struct.setSuccessIsSet(true);
@@ -3139,7 +3670,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchAll_args implements org.apache.thrift.TBase<fetchAll_args, fetchAll_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchAll_args implements org.apache.thrift.TBase<fetchAll_args, fetchAll_args._Fields>, java.io.Serializable, Cloneable, Comparable<fetchAll_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchAll_args");
 
 
@@ -3269,18 +3800,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchAll_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchAll_args typedOther = (fetchAll_args)other;
 
       return 0;
     }
@@ -3385,7 +3916,7 @@ public class ThriftHive {
 
   }
 
-  public static class fetchAll_result implements org.apache.thrift.TBase<fetchAll_result, fetchAll_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class fetchAll_result implements org.apache.thrift.TBase<fetchAll_result, fetchAll_result._Fields>, java.io.Serializable, Cloneable, Comparable<fetchAll_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("fetchAll_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.LIST, (short)0);
@@ -3491,10 +4022,7 @@ public class ThriftHive {
      */
     public fetchAll_result(fetchAll_result other) {
       if (other.isSetSuccess()) {
-        List<String> __this__success = new ArrayList<String>();
-        for (String other_element : other.success) {
-          __this__success.add(other_element);
-        }
+        List<String> __this__success = new ArrayList<String>(other.success);
         this.success = __this__success;
       }
       if (other.isSetEx()) {
@@ -3657,45 +4185,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(fetchAll_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      fetchAll_result typedOther = (fetchAll_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -3783,11 +4311,11 @@ public class ThriftHive {
                 {
                   org.apache.thrift.protocol.TList _list8 = iprot.readListBegin();
                   struct.success = new ArrayList<String>(_list8.size);
-                  for (int _i9 = 0; _i9 < _list8.size; ++_i9)
+                  String _elem9;
+                  for (int _i10 = 0; _i10 < _list8.size; ++_i10)
                   {
-                    String _elem10; // optional
-                    _elem10 = iprot.readString();
-                    struct.success.add(_elem10);
+                    _elem9 = iprot.readString();
+                    struct.success.add(_elem9);
                   }
                   iprot.readListEnd();
                 }
@@ -3882,11 +4410,11 @@ public class ThriftHive {
           {
             org.apache.thrift.protocol.TList _list13 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
             struct.success = new ArrayList<String>(_list13.size);
-            for (int _i14 = 0; _i14 < _list13.size; ++_i14)
+            String _elem14;
+            for (int _i15 = 0; _i15 < _list13.size; ++_i15)
             {
-              String _elem15; // optional
-              _elem15 = iprot.readString();
-              struct.success.add(_elem15);
+              _elem14 = iprot.readString();
+              struct.success.add(_elem14);
             }
           }
           struct.setSuccessIsSet(true);
@@ -3901,7 +4429,7 @@ public class ThriftHive {
 
   }
 
-  public static class getSchema_args implements org.apache.thrift.TBase<getSchema_args, getSchema_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class getSchema_args implements org.apache.thrift.TBase<getSchema_args, getSchema_args._Fields>, java.io.Serializable, Cloneable, Comparable<getSchema_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getSchema_args");
 
 
@@ -4031,18 +4559,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getSchema_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getSchema_args typedOther = (getSchema_args)other;
 
       return 0;
     }
@@ -4147,7 +4675,7 @@ public class ThriftHive {
 
   }
 
-  public static class getSchema_result implements org.apache.thrift.TBase<getSchema_result, getSchema_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class getSchema_result implements org.apache.thrift.TBase<getSchema_result, getSchema_result._Fields>, java.io.Serializable, Cloneable, Comparable<getSchema_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getSchema_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -4399,45 +4927,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getSchema_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getSchema_result typedOther = (getSchema_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -4616,7 +5144,7 @@ public class ThriftHive {
 
   }
 
-  public static class getThriftSchema_args implements org.apache.thrift.TBase<getThriftSchema_args, getThriftSchema_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class getThriftSchema_args implements org.apache.thrift.TBase<getThriftSchema_args, getThriftSchema_args._Fields>, java.io.Serializable, Cloneable, Comparable<getThriftSchema_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getThriftSchema_args");
 
 
@@ -4746,18 +5274,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getThriftSchema_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getThriftSchema_args typedOther = (getThriftSchema_args)other;
 
       return 0;
     }
@@ -4862,7 +5390,7 @@ public class ThriftHive {
 
   }
 
-  public static class getThriftSchema_result implements org.apache.thrift.TBase<getThriftSchema_result, getThriftSchema_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class getThriftSchema_result implements org.apache.thrift.TBase<getThriftSchema_result, getThriftSchema_result._Fields>, java.io.Serializable, Cloneable, Comparable<getThriftSchema_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getThriftSchema_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -5114,45 +5642,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getThriftSchema_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getThriftSchema_result typedOther = (getThriftSchema_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -5331,7 +5859,7 @@ public class ThriftHive {
 
   }
 
-  public static class getClusterStatus_args implements org.apache.thrift.TBase<getClusterStatus_args, getClusterStatus_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class getClusterStatus_args implements org.apache.thrift.TBase<getClusterStatus_args, getClusterStatus_args._Fields>, java.io.Serializable, Cloneable, Comparable<getClusterStatus_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getClusterStatus_args");
 
 
@@ -5461,18 +5989,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getClusterStatus_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getClusterStatus_args typedOther = (getClusterStatus_args)other;
 
       return 0;
     }
@@ -5577,7 +6105,7 @@ public class ThriftHive {
 
   }
 
-  public static class getClusterStatus_result implements org.apache.thrift.TBase<getClusterStatus_result, getClusterStatus_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class getClusterStatus_result implements org.apache.thrift.TBase<getClusterStatus_result, getClusterStatus_result._Fields>, java.io.Serializable, Cloneable, Comparable<getClusterStatus_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getClusterStatus_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -5829,45 +6357,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getClusterStatus_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getClusterStatus_result typedOther = (getClusterStatus_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -6046,7 +6574,7 @@ public class ThriftHive {
 
   }
 
-  public static class getQueryPlan_args implements org.apache.thrift.TBase<getQueryPlan_args, getQueryPlan_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class getQueryPlan_args implements org.apache.thrift.TBase<getQueryPlan_args, getQueryPlan_args._Fields>, java.io.Serializable, Cloneable, Comparable<getQueryPlan_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getQueryPlan_args");
 
 
@@ -6176,18 +6704,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getQueryPlan_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getQueryPlan_args typedOther = (getQueryPlan_args)other;
 
       return 0;
     }
@@ -6292,7 +6820,7 @@ public class ThriftHive {
 
   }
 
-  public static class getQueryPlan_result implements org.apache.thrift.TBase<getQueryPlan_result, getQueryPlan_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class getQueryPlan_result implements org.apache.thrift.TBase<getQueryPlan_result, getQueryPlan_result._Fields>, java.io.Serializable, Cloneable, Comparable<getQueryPlan_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("getQueryPlan_result");
 
     private static final org.apache.thrift.protocol.TField SUCCESS_FIELD_DESC = new org.apache.thrift.protocol.TField("success", org.apache.thrift.protocol.TType.STRUCT, (short)0);
@@ -6544,45 +7072,45 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
       boolean present_success = true && (isSetSuccess());
-      builder.append(present_success);
+      list.add(present_success);
       if (present_success)
-        builder.append(success);
+        list.add(success);
 
       boolean present_ex = true && (isSetEx());
-      builder.append(present_ex);
+      list.add(present_ex);
       if (present_ex)
-        builder.append(ex);
+        list.add(ex);
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(getQueryPlan_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      getQueryPlan_result typedOther = (getQueryPlan_result)other;
 
-      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(typedOther.isSetSuccess());
+      lastComparison = Boolean.valueOf(isSetSuccess()).compareTo(other.isSetSuccess());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetSuccess()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, typedOther.success);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.success, other.success);
         if (lastComparison != 0) {
           return lastComparison;
         }
       }
-      lastComparison = Boolean.valueOf(isSetEx()).compareTo(typedOther.isSetEx());
+      lastComparison = Boolean.valueOf(isSetEx()).compareTo(other.isSetEx());
       if (lastComparison != 0) {
         return lastComparison;
       }
       if (isSetEx()) {
-        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, typedOther.ex);
+        lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.ex, other.ex);
         if (lastComparison != 0) {
           return lastComparison;
         }
@@ -6761,7 +7289,7 @@ public class ThriftHive {
 
   }
 
-  public static class clean_args implements org.apache.thrift.TBase<clean_args, clean_args._Fields>, java.io.Serializable, Cloneable   {
+  public static class clean_args implements org.apache.thrift.TBase<clean_args, clean_args._Fields>, java.io.Serializable, Cloneable, Comparable<clean_args>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("clean_args");
 
 
@@ -6891,18 +7419,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(clean_args other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      clean_args typedOther = (clean_args)other;
 
       return 0;
     }
@@ -7007,7 +7535,7 @@ public class ThriftHive {
 
   }
 
-  public static class clean_result implements org.apache.thrift.TBase<clean_result, clean_result._Fields>, java.io.Serializable, Cloneable   {
+  public static class clean_result implements org.apache.thrift.TBase<clean_result, clean_result._Fields>, java.io.Serializable, Cloneable, Comparable<clean_result>   {
     private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("clean_result");
 
 
@@ -7137,18 +7665,18 @@ public class ThriftHive {
 
     @Override
     public int hashCode() {
-      HashCodeBuilder builder = new HashCodeBuilder();
+      List<Object> list = new ArrayList<Object>();
 
-      return builder.toHashCode();
+      return list.hashCode();
     }
 
+    @Override
     public int compareTo(clean_result other) {
       if (!getClass().equals(other.getClass())) {
         return getClass().getName().compareTo(other.getClass().getName());
       }
 
       int lastComparison = 0;
-      clean_result typedOther = (clean_result)other;
 
       return 0;
     }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TArrayTypeEntry.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TArrayTypeEntry.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TArrayTypeEntry.java
index 6323d34..8d18125 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TArrayTypeEntry.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TArrayTypeEntry.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TArrayTypeEntry implements org.apache.thrift.TBase<TArrayTypeEntry, TArrayTypeEntry._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TArrayTypeEntry implements org.apache.thrift.TBase<TArrayTypeEntry, TArrayTypeEntry._Fields>, java.io.Serializable, Cloneable, Comparable<TArrayTypeEntry> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TArrayTypeEntry");
 
   private static final org.apache.thrift.protocol.TField OBJECT_TYPE_PTR_FIELD_DESC = new org.apache.thrift.protocol.TField("objectTypePtr", org.apache.thrift.protocol.TType.I32, (short)1);
@@ -227,30 +231,30 @@ public class TArrayTypeEntry implements org.apache.thrift.TBase<TArrayTypeEntry,
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_objectTypePtr = true;
-    builder.append(present_objectTypePtr);
+    list.add(present_objectTypePtr);
     if (present_objectTypePtr)
-      builder.append(objectTypePtr);
+      list.add(objectTypePtr);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TArrayTypeEntry other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TArrayTypeEntry typedOther = (TArrayTypeEntry)other;
 
-    lastComparison = Boolean.valueOf(isSetObjectTypePtr()).compareTo(typedOther.isSetObjectTypePtr());
+    lastComparison = Boolean.valueOf(isSetObjectTypePtr()).compareTo(other.isSetObjectTypePtr());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetObjectTypePtr()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectTypePtr, typedOther.objectTypePtr);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.objectTypePtr, other.objectTypePtr);
       if (lastComparison != 0) {
         return lastComparison;
       }

http://git-wip-us.apache.org/repos/asf/hive/blob/42216997/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBinaryColumn.java
----------------------------------------------------------------------
diff --git a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBinaryColumn.java b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBinaryColumn.java
index 6b1b054..255726a 100644
--- a/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBinaryColumn.java
+++ b/service/src/gen/thrift/gen-javabean/org/apache/hive/service/cli/thrift/TBinaryColumn.java
@@ -1,12 +1,11 @@
 /**
- * Autogenerated by Thrift Compiler (0.9.0)
+ * Autogenerated by Thrift Compiler (0.9.2)
  *
  * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
  *  @generated
  */
 package org.apache.hive.service.cli.thrift;
 
-import org.apache.commons.lang.builder.HashCodeBuilder;
 import org.apache.thrift.scheme.IScheme;
 import org.apache.thrift.scheme.SchemeFactory;
 import org.apache.thrift.scheme.StandardScheme;
@@ -16,6 +15,8 @@ import org.apache.thrift.protocol.TTupleProtocol;
 import org.apache.thrift.protocol.TProtocolException;
 import org.apache.thrift.EncodingUtils;
 import org.apache.thrift.TException;
+import org.apache.thrift.async.AsyncMethodCallback;
+import org.apache.thrift.server.AbstractNonblockingServer.*;
 import java.util.List;
 import java.util.ArrayList;
 import java.util.Map;
@@ -28,10 +29,13 @@ import java.util.Collections;
 import java.util.BitSet;
 import java.nio.ByteBuffer;
 import java.util.Arrays;
+import javax.annotation.Generated;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
-public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBinaryColumn._Fields>, java.io.Serializable, Cloneable {
+@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
+@Generated(value = "Autogenerated by Thrift Compiler (0.9.2)", date = "2015-7-14")
+public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBinaryColumn._Fields>, java.io.Serializable, Cloneable, Comparable<TBinaryColumn> {
   private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("TBinaryColumn");
 
   private static final org.apache.thrift.protocol.TField VALUES_FIELD_DESC = new org.apache.thrift.protocol.TField("values", org.apache.thrift.protocol.TType.LIST, (short)1);
@@ -129,7 +133,7 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
   {
     this();
     this.values = values;
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   /**
@@ -137,17 +141,11 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
    */
   public TBinaryColumn(TBinaryColumn other) {
     if (other.isSetValues()) {
-      List<ByteBuffer> __this__values = new ArrayList<ByteBuffer>();
-      for (ByteBuffer other_element : other.values) {
-        ByteBuffer temp_binary_element = org.apache.thrift.TBaseHelper.copyBinary(other_element);
-;
-        __this__values.add(temp_binary_element);
-      }
+      List<ByteBuffer> __this__values = new ArrayList<ByteBuffer>(other.values);
       this.values = __this__values;
     }
     if (other.isSetNulls()) {
       this.nulls = org.apache.thrift.TBaseHelper.copyBinary(other.nulls);
-;
     }
   }
 
@@ -205,15 +203,15 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
   }
 
   public ByteBuffer bufferForNulls() {
-    return nulls;
+    return org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void setNulls(byte[] nulls) {
-    setNulls(nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(nulls));
+    this.nulls = nulls == null ? (ByteBuffer)null : ByteBuffer.wrap(Arrays.copyOf(nulls, nulls.length));
   }
 
   public void setNulls(ByteBuffer nulls) {
-    this.nulls = nulls;
+    this.nulls = org.apache.thrift.TBaseHelper.copyBinary(nulls);
   }
 
   public void unsetNulls() {
@@ -315,45 +313,45 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
 
   @Override
   public int hashCode() {
-    HashCodeBuilder builder = new HashCodeBuilder();
+    List<Object> list = new ArrayList<Object>();
 
     boolean present_values = true && (isSetValues());
-    builder.append(present_values);
+    list.add(present_values);
     if (present_values)
-      builder.append(values);
+      list.add(values);
 
     boolean present_nulls = true && (isSetNulls());
-    builder.append(present_nulls);
+    list.add(present_nulls);
     if (present_nulls)
-      builder.append(nulls);
+      list.add(nulls);
 
-    return builder.toHashCode();
+    return list.hashCode();
   }
 
+  @Override
   public int compareTo(TBinaryColumn other) {
     if (!getClass().equals(other.getClass())) {
       return getClass().getName().compareTo(other.getClass().getName());
     }
 
     int lastComparison = 0;
-    TBinaryColumn typedOther = (TBinaryColumn)other;
 
-    lastComparison = Boolean.valueOf(isSetValues()).compareTo(typedOther.isSetValues());
+    lastComparison = Boolean.valueOf(isSetValues()).compareTo(other.isSetValues());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetValues()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, typedOther.values);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.values, other.values);
       if (lastComparison != 0) {
         return lastComparison;
       }
     }
-    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(typedOther.isSetNulls());
+    lastComparison = Boolean.valueOf(isSetNulls()).compareTo(other.isSetNulls());
     if (lastComparison != 0) {
       return lastComparison;
     }
     if (isSetNulls()) {
-      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, typedOther.nulls);
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nulls, other.nulls);
       if (lastComparison != 0) {
         return lastComparison;
       }
@@ -449,11 +447,11 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
               {
                 org.apache.thrift.protocol.TList _list110 = iprot.readListBegin();
                 struct.values = new ArrayList<ByteBuffer>(_list110.size);
-                for (int _i111 = 0; _i111 < _list110.size; ++_i111)
+                ByteBuffer _elem111;
+                for (int _i112 = 0; _i112 < _list110.size; ++_i112)
                 {
-                  ByteBuffer _elem112; // optional
-                  _elem112 = iprot.readBinary();
-                  struct.values.add(_elem112);
+                  _elem111 = iprot.readBinary();
+                  struct.values.add(_elem111);
                 }
                 iprot.readListEnd();
               }
@@ -533,11 +531,11 @@ public class TBinaryColumn implements org.apache.thrift.TBase<TBinaryColumn, TBi
       {
         org.apache.thrift.protocol.TList _list115 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
         struct.values = new ArrayList<ByteBuffer>(_list115.size);
-        for (int _i116 = 0; _i116 < _list115.size; ++_i116)
+        ByteBuffer _elem116;
+        for (int _i117 = 0; _i117 < _list115.size; ++_i117)
         {
-          ByteBuffer _elem117; // optional
-          _elem117 = iprot.readBinary();
-          struct.values.add(_elem117);
+          _elem116 = iprot.readBinary();
+          struct.values.add(_elem116);
         }
       }
       struct.setValuesIsSet(true);