You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by jv...@apache.org on 2010/07/30 08:40:11 UTC

svn commit: r980659 [3/34] - in /hadoop/hive/trunk: ./ common/src/java/org/apache/hadoop/hive/common/ contrib/src/test/results/clientpositive/ metastore/if/ metastore/src/gen-cpp/ metastore/src/gen-javabean/org/apache/hadoop/hive/metastore/api/ metasto...

Modified: hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore.h
URL: http://svn.apache.org/viewvc/hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore.h?rev=980659&r1=980658&r2=980659&view=diff
==============================================================================
--- hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore.h (original)
+++ hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore.h Fri Jul 30 06:40:04 2010
@@ -45,6 +45,11 @@ class ThriftHiveMetastoreIf : virtual pu
   virtual void get_config_value(std::string& _return, const std::string& name, const std::string& defaultValue) = 0;
   virtual void partition_name_to_vals(std::vector<std::string> & _return, const std::string& part_name) = 0;
   virtual void partition_name_to_spec(std::map<std::string, std::string> & _return, const std::string& part_name) = 0;
+  virtual void add_index(Index& _return, const Index& new_index, const Table& index_table) = 0;
+  virtual bool drop_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name, const bool deleteData) = 0;
+  virtual void get_index_by_name(Index& _return, const std::string& db_name, const std::string& tbl_name, const std::string& index_name) = 0;
+  virtual void get_indexes(std::vector<Index> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) = 0;
+  virtual void get_index_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) = 0;
 };
 
 class ThriftHiveMetastoreNull : virtual public ThriftHiveMetastoreIf , virtual public facebook::fb303::FacebookServiceNull {
@@ -146,6 +151,22 @@ class ThriftHiveMetastoreNull : virtual 
   void partition_name_to_spec(std::map<std::string, std::string> & /* _return */, const std::string& /* part_name */) {
     return;
   }
+  void add_index(Index& /* _return */, const Index& /* new_index */, const Table& /* index_table */) {
+    return;
+  }
+  bool drop_index_by_name(const std::string& /* db_name */, const std::string& /* tbl_name */, const std::string& /* index_name */, const bool /* deleteData */) {
+    bool _return = false;
+    return _return;
+  }
+  void get_index_by_name(Index& /* _return */, const std::string& /* db_name */, const std::string& /* tbl_name */, const std::string& /* index_name */) {
+    return;
+  }
+  void get_indexes(std::vector<Index> & /* _return */, const std::string& /* db_name */, const std::string& /* tbl_name */, const int16_t /* max_indexes */) {
+    return;
+  }
+  void get_index_names(std::vector<std::string> & /* _return */, const std::string& /* db_name */, const std::string& /* tbl_name */, const int16_t /* max_indexes */) {
+    return;
+  }
 };
 
 class ThriftHiveMetastore_create_database_args {
@@ -3421,242 +3442,842 @@ class ThriftHiveMetastore_partition_name
 
 };
 
-class ThriftHiveMetastoreClient : virtual public ThriftHiveMetastoreIf, public facebook::fb303::FacebookServiceClient {
+class ThriftHiveMetastore_add_index_args {
  public:
-  ThriftHiveMetastoreClient(boost::shared_ptr<apache::thrift::protocol::TProtocol> prot) :
-    facebook::fb303::FacebookServiceClient(prot, prot) {}
-  ThriftHiveMetastoreClient(boost::shared_ptr<apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr<apache::thrift::protocol::TProtocol> oprot) :
-    facebook::fb303::FacebookServiceClient(iprot, oprot) {}
-  boost::shared_ptr<apache::thrift::protocol::TProtocol> getInputProtocol() {
-    return piprot_;
+
+  ThriftHiveMetastore_add_index_args() {
   }
-  boost::shared_ptr<apache::thrift::protocol::TProtocol> getOutputProtocol() {
-    return poprot_;
+
+  virtual ~ThriftHiveMetastore_add_index_args() throw() {}
+
+  Index new_index;
+  Table index_table;
+
+  struct __isset {
+    __isset() : new_index(false), index_table(false) {}
+    bool new_index;
+    bool index_table;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_add_index_args & rhs) const
+  {
+    if (!(new_index == rhs.new_index))
+      return false;
+    if (!(index_table == rhs.index_table))
+      return false;
+    return true;
   }
-  bool create_database(const std::string& name, const std::string& description);
-  void send_create_database(const std::string& name, const std::string& description);
-  bool recv_create_database();
-  void get_database(Database& _return, const std::string& name);
-  void send_get_database(const std::string& name);
-  void recv_get_database(Database& _return);
-  bool drop_database(const std::string& name);
-  void send_drop_database(const std::string& name);
-  bool recv_drop_database();
-  void get_databases(std::vector<std::string> & _return);
-  void send_get_databases();
-  void recv_get_databases(std::vector<std::string> & _return);
-  void get_type(Type& _return, const std::string& name);
-  void send_get_type(const std::string& name);
-  void recv_get_type(Type& _return);
-  bool create_type(const Type& type);
-  void send_create_type(const Type& type);
-  bool recv_create_type();
-  bool drop_type(const std::string& type);
-  void send_drop_type(const std::string& type);
-  bool recv_drop_type();
-  void get_type_all(std::map<std::string, Type> & _return, const std::string& name);
-  void send_get_type_all(const std::string& name);
-  void recv_get_type_all(std::map<std::string, Type> & _return);
-  void get_fields(std::vector<FieldSchema> & _return, const std::string& db_name, const std::string& table_name);
-  void send_get_fields(const std::string& db_name, const std::string& table_name);
-  void recv_get_fields(std::vector<FieldSchema> & _return);
-  void get_schema(std::vector<FieldSchema> & _return, const std::string& db_name, const std::string& table_name);
-  void send_get_schema(const std::string& db_name, const std::string& table_name);
-  void recv_get_schema(std::vector<FieldSchema> & _return);
-  void create_table(const Table& tbl);
-  void send_create_table(const Table& tbl);
-  void recv_create_table();
-  void drop_table(const std::string& dbname, const std::string& name, const bool deleteData);
-  void send_drop_table(const std::string& dbname, const std::string& name, const bool deleteData);
-  void recv_drop_table();
-  void get_tables(std::vector<std::string> & _return, const std::string& db_name, const std::string& pattern);
-  void send_get_tables(const std::string& db_name, const std::string& pattern);
-  void recv_get_tables(std::vector<std::string> & _return);
-  void get_table(Table& _return, const std::string& dbname, const std::string& tbl_name);
-  void send_get_table(const std::string& dbname, const std::string& tbl_name);
-  void recv_get_table(Table& _return);
-  void alter_table(const std::string& dbname, const std::string& tbl_name, const Table& new_tbl);
-  void send_alter_table(const std::string& dbname, const std::string& tbl_name, const Table& new_tbl);
-  void recv_alter_table();
-  void add_partition(Partition& _return, const Partition& new_part);
-  void send_add_partition(const Partition& new_part);
-  void recv_add_partition(Partition& _return);
-  void append_partition(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
-  void send_append_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
-  void recv_append_partition(Partition& _return);
-  void append_partition_by_name(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
-  void send_append_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
-  void recv_append_partition_by_name(Partition& _return);
-  bool drop_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const bool deleteData);
-  void send_drop_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const bool deleteData);
-  bool recv_drop_partition();
-  bool drop_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name, const bool deleteData);
-  void send_drop_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name, const bool deleteData);
-  bool recv_drop_partition_by_name();
-  void get_partition(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
-  void send_get_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
-  void recv_get_partition(Partition& _return);
-  void get_partition_by_name(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
-  void send_get_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
-  void recv_get_partition_by_name(Partition& _return);
-  void get_partitions(std::vector<Partition> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
-  void send_get_partitions(const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
-  void recv_get_partitions(std::vector<Partition> & _return);
-  void get_partition_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
-  void send_get_partition_names(const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
-  void recv_get_partition_names(std::vector<std::string> & _return);
-  void get_partitions_ps(std::vector<Partition> & _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
-  void send_get_partitions_ps(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
-  void recv_get_partitions_ps(std::vector<Partition> & _return);
-  void get_partition_names_ps(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
-  void send_get_partition_names_ps(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
-  void recv_get_partition_names_ps(std::vector<std::string> & _return);
-  void alter_partition(const std::string& db_name, const std::string& tbl_name, const Partition& new_part);
-  void send_alter_partition(const std::string& db_name, const std::string& tbl_name, const Partition& new_part);
-  void recv_alter_partition();
-  void get_config_value(std::string& _return, const std::string& name, const std::string& defaultValue);
-  void send_get_config_value(const std::string& name, const std::string& defaultValue);
-  void recv_get_config_value(std::string& _return);
-  void partition_name_to_vals(std::vector<std::string> & _return, const std::string& part_name);
-  void send_partition_name_to_vals(const std::string& part_name);
-  void recv_partition_name_to_vals(std::vector<std::string> & _return);
-  void partition_name_to_spec(std::map<std::string, std::string> & _return, const std::string& part_name);
-  void send_partition_name_to_spec(const std::string& part_name);
-  void recv_partition_name_to_spec(std::map<std::string, std::string> & _return);
+  bool operator != (const ThriftHiveMetastore_add_index_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_add_index_args & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
 };
 
-class ThriftHiveMetastoreProcessor : virtual public apache::thrift::TProcessor, public facebook::fb303::FacebookServiceProcessor {
- protected:
-  boost::shared_ptr<ThriftHiveMetastoreIf> iface_;
-  virtual bool process_fn(apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot, std::string& fname, int32_t seqid);
- private:
-  std::map<std::string, void (ThriftHiveMetastoreProcessor::*)(int32_t, apache::thrift::protocol::TProtocol*, apache::thrift::protocol::TProtocol*)> processMap_;
-  void process_create_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_drop_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_databases(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_create_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_drop_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_type_all(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_fields(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_schema(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_create_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_drop_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_tables(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_alter_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_add_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_append_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_append_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_drop_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_drop_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partitions(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partition_names(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partitions_ps(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_partition_names_ps(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_alter_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_get_config_value(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_partition_name_to_vals(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
-  void process_partition_name_to_spec(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+class ThriftHiveMetastore_add_index_pargs {
  public:
-  ThriftHiveMetastoreProcessor(boost::shared_ptr<ThriftHiveMetastoreIf> iface) :
-    facebook::fb303::FacebookServiceProcessor(iface),
-    iface_(iface) {
-    processMap_["create_database"] = &ThriftHiveMetastoreProcessor::process_create_database;
-    processMap_["get_database"] = &ThriftHiveMetastoreProcessor::process_get_database;
-    processMap_["drop_database"] = &ThriftHiveMetastoreProcessor::process_drop_database;
-    processMap_["get_databases"] = &ThriftHiveMetastoreProcessor::process_get_databases;
-    processMap_["get_type"] = &ThriftHiveMetastoreProcessor::process_get_type;
-    processMap_["create_type"] = &ThriftHiveMetastoreProcessor::process_create_type;
-    processMap_["drop_type"] = &ThriftHiveMetastoreProcessor::process_drop_type;
-    processMap_["get_type_all"] = &ThriftHiveMetastoreProcessor::process_get_type_all;
-    processMap_["get_fields"] = &ThriftHiveMetastoreProcessor::process_get_fields;
-    processMap_["get_schema"] = &ThriftHiveMetastoreProcessor::process_get_schema;
-    processMap_["create_table"] = &ThriftHiveMetastoreProcessor::process_create_table;
-    processMap_["drop_table"] = &ThriftHiveMetastoreProcessor::process_drop_table;
-    processMap_["get_tables"] = &ThriftHiveMetastoreProcessor::process_get_tables;
-    processMap_["get_table"] = &ThriftHiveMetastoreProcessor::process_get_table;
-    processMap_["alter_table"] = &ThriftHiveMetastoreProcessor::process_alter_table;
-    processMap_["add_partition"] = &ThriftHiveMetastoreProcessor::process_add_partition;
-    processMap_["append_partition"] = &ThriftHiveMetastoreProcessor::process_append_partition;
-    processMap_["append_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_append_partition_by_name;
-    processMap_["drop_partition"] = &ThriftHiveMetastoreProcessor::process_drop_partition;
-    processMap_["drop_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_drop_partition_by_name;
-    processMap_["get_partition"] = &ThriftHiveMetastoreProcessor::process_get_partition;
-    processMap_["get_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_get_partition_by_name;
-    processMap_["get_partitions"] = &ThriftHiveMetastoreProcessor::process_get_partitions;
-    processMap_["get_partition_names"] = &ThriftHiveMetastoreProcessor::process_get_partition_names;
-    processMap_["get_partitions_ps"] = &ThriftHiveMetastoreProcessor::process_get_partitions_ps;
-    processMap_["get_partition_names_ps"] = &ThriftHiveMetastoreProcessor::process_get_partition_names_ps;
-    processMap_["alter_partition"] = &ThriftHiveMetastoreProcessor::process_alter_partition;
-    processMap_["get_config_value"] = &ThriftHiveMetastoreProcessor::process_get_config_value;
-    processMap_["partition_name_to_vals"] = &ThriftHiveMetastoreProcessor::process_partition_name_to_vals;
-    processMap_["partition_name_to_spec"] = &ThriftHiveMetastoreProcessor::process_partition_name_to_spec;
-  }
 
-  virtual bool process(boost::shared_ptr<apache::thrift::protocol::TProtocol> piprot, boost::shared_ptr<apache::thrift::protocol::TProtocol> poprot);
-  virtual ~ThriftHiveMetastoreProcessor() {}
+
+  virtual ~ThriftHiveMetastore_add_index_pargs() throw() {}
+
+  const Index* new_index;
+  const Table* index_table;
+
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
 };
 
-class ThriftHiveMetastoreMultiface : virtual public ThriftHiveMetastoreIf, public facebook::fb303::FacebookServiceMultiface {
- public:
-  ThriftHiveMetastoreMultiface(std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> >& ifaces) : ifaces_(ifaces) {
-    std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> >::iterator iter;
-    for (iter = ifaces.begin(); iter != ifaces.end(); ++iter) {
-      facebook::fb303::FacebookServiceMultiface::add(*iter);
-    }
-  }
-  virtual ~ThriftHiveMetastoreMultiface() {}
- protected:
-  std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> > ifaces_;
-  ThriftHiveMetastoreMultiface() {}
-  void add(boost::shared_ptr<ThriftHiveMetastoreIf> iface) {
-    facebook::fb303::FacebookServiceMultiface::add(iface);
-    ifaces_.push_back(iface);
-  }
+class ThriftHiveMetastore_add_index_result {
  public:
-  bool create_database(const std::string& name, const std::string& description) {
-    uint32_t sz = ifaces_.size();
-    for (uint32_t i = 0; i < sz; ++i) {
-      if (i == sz - 1) {
-        return ifaces_[i]->create_database(name, description);
-      } else {
-        ifaces_[i]->create_database(name, description);
-      }
-    }
-  }
 
-  void get_database(Database& _return, const std::string& name) {
-    uint32_t sz = ifaces_.size();
-    for (uint32_t i = 0; i < sz; ++i) {
-      if (i == sz - 1) {
-        ifaces_[i]->get_database(_return, name);
-        return;
-      } else {
-        ifaces_[i]->get_database(_return, name);
-      }
-    }
+  ThriftHiveMetastore_add_index_result() {
   }
 
-  bool drop_database(const std::string& name) {
-    uint32_t sz = ifaces_.size();
-    for (uint32_t i = 0; i < sz; ++i) {
-      if (i == sz - 1) {
-        return ifaces_[i]->drop_database(name);
-      } else {
-        ifaces_[i]->drop_database(name);
-      }
-    }
-  }
+  virtual ~ThriftHiveMetastore_add_index_result() throw() {}
 
-  void get_databases(std::vector<std::string> & _return) {
-    uint32_t sz = ifaces_.size();
-    for (uint32_t i = 0; i < sz; ++i) {
-      if (i == sz - 1) {
-        ifaces_[i]->get_databases(_return);
+  Index success;
+  InvalidObjectException o1;
+  AlreadyExistsException o2;
+  MetaException o3;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false), o3(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+    bool o3;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_add_index_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    if (!(o1 == rhs.o1))
+      return false;
+    if (!(o2 == rhs.o2))
+      return false;
+    if (!(o3 == rhs.o3))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_add_index_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_add_index_result & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_add_index_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_add_index_presult() throw() {}
+
+  Index* success;
+  InvalidObjectException o1;
+  AlreadyExistsException o2;
+  MetaException o3;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false), o3(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+    bool o3;
+  } __isset;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+
+};
+
+class ThriftHiveMetastore_drop_index_by_name_args {
+ public:
+
+  ThriftHiveMetastore_drop_index_by_name_args() : db_name(""), tbl_name(""), index_name(""), deleteData(0) {
+  }
+
+  virtual ~ThriftHiveMetastore_drop_index_by_name_args() throw() {}
+
+  std::string db_name;
+  std::string tbl_name;
+  std::string index_name;
+  bool deleteData;
+
+  struct __isset {
+    __isset() : db_name(false), tbl_name(false), index_name(false), deleteData(false) {}
+    bool db_name;
+    bool tbl_name;
+    bool index_name;
+    bool deleteData;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_drop_index_by_name_args & rhs) const
+  {
+    if (!(db_name == rhs.db_name))
+      return false;
+    if (!(tbl_name == rhs.tbl_name))
+      return false;
+    if (!(index_name == rhs.index_name))
+      return false;
+    if (!(deleteData == rhs.deleteData))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_drop_index_by_name_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_drop_index_by_name_args & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_drop_index_by_name_pargs {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_drop_index_by_name_pargs() throw() {}
+
+  const std::string* db_name;
+  const std::string* tbl_name;
+  const std::string* index_name;
+  const bool* deleteData;
+
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_drop_index_by_name_result {
+ public:
+
+  ThriftHiveMetastore_drop_index_by_name_result() : success(0) {
+  }
+
+  virtual ~ThriftHiveMetastore_drop_index_by_name_result() throw() {}
+
+  bool success;
+  NoSuchObjectException o1;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_drop_index_by_name_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    if (!(o1 == rhs.o1))
+      return false;
+    if (!(o2 == rhs.o2))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_drop_index_by_name_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_drop_index_by_name_result & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_drop_index_by_name_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_drop_index_by_name_presult() throw() {}
+
+  bool* success;
+  NoSuchObjectException o1;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+
+};
+
+class ThriftHiveMetastore_get_index_by_name_args {
+ public:
+
+  ThriftHiveMetastore_get_index_by_name_args() : db_name(""), tbl_name(""), index_name("") {
+  }
+
+  virtual ~ThriftHiveMetastore_get_index_by_name_args() throw() {}
+
+  std::string db_name;
+  std::string tbl_name;
+  std::string index_name;
+
+  struct __isset {
+    __isset() : db_name(false), tbl_name(false), index_name(false) {}
+    bool db_name;
+    bool tbl_name;
+    bool index_name;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_index_by_name_args & rhs) const
+  {
+    if (!(db_name == rhs.db_name))
+      return false;
+    if (!(tbl_name == rhs.tbl_name))
+      return false;
+    if (!(index_name == rhs.index_name))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_index_by_name_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_index_by_name_args & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_by_name_pargs {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_index_by_name_pargs() throw() {}
+
+  const std::string* db_name;
+  const std::string* tbl_name;
+  const std::string* index_name;
+
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_by_name_result {
+ public:
+
+  ThriftHiveMetastore_get_index_by_name_result() {
+  }
+
+  virtual ~ThriftHiveMetastore_get_index_by_name_result() throw() {}
+
+  Index success;
+  MetaException o1;
+  NoSuchObjectException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_index_by_name_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    if (!(o1 == rhs.o1))
+      return false;
+    if (!(o2 == rhs.o2))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_index_by_name_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_index_by_name_result & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_by_name_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_index_by_name_presult() throw() {}
+
+  Index* success;
+  MetaException o1;
+  NoSuchObjectException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+
+};
+
+class ThriftHiveMetastore_get_indexes_args {
+ public:
+
+  ThriftHiveMetastore_get_indexes_args() : db_name(""), tbl_name(""), max_indexes(-1) {
+  }
+
+  virtual ~ThriftHiveMetastore_get_indexes_args() throw() {}
+
+  std::string db_name;
+  std::string tbl_name;
+  int16_t max_indexes;
+
+  struct __isset {
+    __isset() : db_name(false), tbl_name(false), max_indexes(false) {}
+    bool db_name;
+    bool tbl_name;
+    bool max_indexes;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_indexes_args & rhs) const
+  {
+    if (!(db_name == rhs.db_name))
+      return false;
+    if (!(tbl_name == rhs.tbl_name))
+      return false;
+    if (!(max_indexes == rhs.max_indexes))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_indexes_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_indexes_args & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_indexes_pargs {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_indexes_pargs() throw() {}
+
+  const std::string* db_name;
+  const std::string* tbl_name;
+  const int16_t* max_indexes;
+
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_indexes_result {
+ public:
+
+  ThriftHiveMetastore_get_indexes_result() {
+  }
+
+  virtual ~ThriftHiveMetastore_get_indexes_result() throw() {}
+
+  std::vector<Index>  success;
+  NoSuchObjectException o1;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_indexes_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    if (!(o1 == rhs.o1))
+      return false;
+    if (!(o2 == rhs.o2))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_indexes_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_indexes_result & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_indexes_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_indexes_presult() throw() {}
+
+  std::vector<Index> * success;
+  NoSuchObjectException o1;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o1(false), o2(false) {}
+    bool success;
+    bool o1;
+    bool o2;
+  } __isset;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+
+};
+
+class ThriftHiveMetastore_get_index_names_args {
+ public:
+
+  ThriftHiveMetastore_get_index_names_args() : db_name(""), tbl_name(""), max_indexes(-1) {
+  }
+
+  virtual ~ThriftHiveMetastore_get_index_names_args() throw() {}
+
+  std::string db_name;
+  std::string tbl_name;
+  int16_t max_indexes;
+
+  struct __isset {
+    __isset() : db_name(false), tbl_name(false), max_indexes(false) {}
+    bool db_name;
+    bool tbl_name;
+    bool max_indexes;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_index_names_args & rhs) const
+  {
+    if (!(db_name == rhs.db_name))
+      return false;
+    if (!(tbl_name == rhs.tbl_name))
+      return false;
+    if (!(max_indexes == rhs.max_indexes))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_index_names_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_index_names_args & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_names_pargs {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_index_names_pargs() throw() {}
+
+  const std::string* db_name;
+  const std::string* tbl_name;
+  const int16_t* max_indexes;
+
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_names_result {
+ public:
+
+  ThriftHiveMetastore_get_index_names_result() {
+  }
+
+  virtual ~ThriftHiveMetastore_get_index_names_result() throw() {}
+
+  std::vector<std::string>  success;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o2(false) {}
+    bool success;
+    bool o2;
+  } __isset;
+
+  bool operator == (const ThriftHiveMetastore_get_index_names_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    if (!(o2 == rhs.o2))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_get_index_names_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_get_index_names_result & ) const;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+class ThriftHiveMetastore_get_index_names_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_get_index_names_presult() throw() {}
+
+  std::vector<std::string> * success;
+  MetaException o2;
+
+  struct __isset {
+    __isset() : success(false), o2(false) {}
+    bool success;
+    bool o2;
+  } __isset;
+
+  uint32_t read(apache::thrift::protocol::TProtocol* iprot);
+
+};
+
+class ThriftHiveMetastoreClient : virtual public ThriftHiveMetastoreIf, public facebook::fb303::FacebookServiceClient {
+ public:
+  ThriftHiveMetastoreClient(boost::shared_ptr<apache::thrift::protocol::TProtocol> prot) :
+    facebook::fb303::FacebookServiceClient(prot, prot) {}
+  ThriftHiveMetastoreClient(boost::shared_ptr<apache::thrift::protocol::TProtocol> iprot, boost::shared_ptr<apache::thrift::protocol::TProtocol> oprot) :
+    facebook::fb303::FacebookServiceClient(iprot, oprot) {}
+  boost::shared_ptr<apache::thrift::protocol::TProtocol> getInputProtocol() {
+    return piprot_;
+  }
+  boost::shared_ptr<apache::thrift::protocol::TProtocol> getOutputProtocol() {
+    return poprot_;
+  }
+  bool create_database(const std::string& name, const std::string& description);
+  void send_create_database(const std::string& name, const std::string& description);
+  bool recv_create_database();
+  void get_database(Database& _return, const std::string& name);
+  void send_get_database(const std::string& name);
+  void recv_get_database(Database& _return);
+  bool drop_database(const std::string& name);
+  void send_drop_database(const std::string& name);
+  bool recv_drop_database();
+  void get_databases(std::vector<std::string> & _return);
+  void send_get_databases();
+  void recv_get_databases(std::vector<std::string> & _return);
+  void get_type(Type& _return, const std::string& name);
+  void send_get_type(const std::string& name);
+  void recv_get_type(Type& _return);
+  bool create_type(const Type& type);
+  void send_create_type(const Type& type);
+  bool recv_create_type();
+  bool drop_type(const std::string& type);
+  void send_drop_type(const std::string& type);
+  bool recv_drop_type();
+  void get_type_all(std::map<std::string, Type> & _return, const std::string& name);
+  void send_get_type_all(const std::string& name);
+  void recv_get_type_all(std::map<std::string, Type> & _return);
+  void get_fields(std::vector<FieldSchema> & _return, const std::string& db_name, const std::string& table_name);
+  void send_get_fields(const std::string& db_name, const std::string& table_name);
+  void recv_get_fields(std::vector<FieldSchema> & _return);
+  void get_schema(std::vector<FieldSchema> & _return, const std::string& db_name, const std::string& table_name);
+  void send_get_schema(const std::string& db_name, const std::string& table_name);
+  void recv_get_schema(std::vector<FieldSchema> & _return);
+  void create_table(const Table& tbl);
+  void send_create_table(const Table& tbl);
+  void recv_create_table();
+  void drop_table(const std::string& dbname, const std::string& name, const bool deleteData);
+  void send_drop_table(const std::string& dbname, const std::string& name, const bool deleteData);
+  void recv_drop_table();
+  void get_tables(std::vector<std::string> & _return, const std::string& db_name, const std::string& pattern);
+  void send_get_tables(const std::string& db_name, const std::string& pattern);
+  void recv_get_tables(std::vector<std::string> & _return);
+  void get_table(Table& _return, const std::string& dbname, const std::string& tbl_name);
+  void send_get_table(const std::string& dbname, const std::string& tbl_name);
+  void recv_get_table(Table& _return);
+  void alter_table(const std::string& dbname, const std::string& tbl_name, const Table& new_tbl);
+  void send_alter_table(const std::string& dbname, const std::string& tbl_name, const Table& new_tbl);
+  void recv_alter_table();
+  void add_partition(Partition& _return, const Partition& new_part);
+  void send_add_partition(const Partition& new_part);
+  void recv_add_partition(Partition& _return);
+  void append_partition(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
+  void send_append_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
+  void recv_append_partition(Partition& _return);
+  void append_partition_by_name(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
+  void send_append_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
+  void recv_append_partition_by_name(Partition& _return);
+  bool drop_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const bool deleteData);
+  void send_drop_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const bool deleteData);
+  bool recv_drop_partition();
+  bool drop_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name, const bool deleteData);
+  void send_drop_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name, const bool deleteData);
+  bool recv_drop_partition_by_name();
+  void get_partition(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
+  void send_get_partition(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals);
+  void recv_get_partition(Partition& _return);
+  void get_partition_by_name(Partition& _return, const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
+  void send_get_partition_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& part_name);
+  void recv_get_partition_by_name(Partition& _return);
+  void get_partitions(std::vector<Partition> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
+  void send_get_partitions(const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
+  void recv_get_partitions(std::vector<Partition> & _return);
+  void get_partition_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
+  void send_get_partition_names(const std::string& db_name, const std::string& tbl_name, const int16_t max_parts);
+  void recv_get_partition_names(std::vector<std::string> & _return);
+  void get_partitions_ps(std::vector<Partition> & _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
+  void send_get_partitions_ps(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
+  void recv_get_partitions_ps(std::vector<Partition> & _return);
+  void get_partition_names_ps(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
+  void send_get_partition_names_ps(const std::string& db_name, const std::string& tbl_name, const std::vector<std::string> & part_vals, const int16_t max_parts);
+  void recv_get_partition_names_ps(std::vector<std::string> & _return);
+  void alter_partition(const std::string& db_name, const std::string& tbl_name, const Partition& new_part);
+  void send_alter_partition(const std::string& db_name, const std::string& tbl_name, const Partition& new_part);
+  void recv_alter_partition();
+  void get_config_value(std::string& _return, const std::string& name, const std::string& defaultValue);
+  void send_get_config_value(const std::string& name, const std::string& defaultValue);
+  void recv_get_config_value(std::string& _return);
+  void partition_name_to_vals(std::vector<std::string> & _return, const std::string& part_name);
+  void send_partition_name_to_vals(const std::string& part_name);
+  void recv_partition_name_to_vals(std::vector<std::string> & _return);
+  void partition_name_to_spec(std::map<std::string, std::string> & _return, const std::string& part_name);
+  void send_partition_name_to_spec(const std::string& part_name);
+  void recv_partition_name_to_spec(std::map<std::string, std::string> & _return);
+  void add_index(Index& _return, const Index& new_index, const Table& index_table);
+  void send_add_index(const Index& new_index, const Table& index_table);
+  void recv_add_index(Index& _return);
+  bool drop_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name, const bool deleteData);
+  void send_drop_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name, const bool deleteData);
+  bool recv_drop_index_by_name();
+  void get_index_by_name(Index& _return, const std::string& db_name, const std::string& tbl_name, const std::string& index_name);
+  void send_get_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name);
+  void recv_get_index_by_name(Index& _return);
+  void get_indexes(std::vector<Index> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes);
+  void send_get_indexes(const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes);
+  void recv_get_indexes(std::vector<Index> & _return);
+  void get_index_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes);
+  void send_get_index_names(const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes);
+  void recv_get_index_names(std::vector<std::string> & _return);
+};
+
+class ThriftHiveMetastoreProcessor : virtual public apache::thrift::TProcessor, public facebook::fb303::FacebookServiceProcessor {
+ protected:
+  boost::shared_ptr<ThriftHiveMetastoreIf> iface_;
+  virtual bool process_fn(apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot, std::string& fname, int32_t seqid);
+ private:
+  std::map<std::string, void (ThriftHiveMetastoreProcessor::*)(int32_t, apache::thrift::protocol::TProtocol*, apache::thrift::protocol::TProtocol*)> processMap_;
+  void process_create_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_database(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_databases(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_create_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_type(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_type_all(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_fields(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_schema(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_create_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_tables(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_alter_table(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_add_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_append_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_append_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partition_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partitions(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partition_names(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partitions_ps(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_partition_names_ps(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_alter_partition(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_config_value(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_partition_name_to_vals(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_partition_name_to_spec(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_add_index(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_drop_index_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_index_by_name(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_indexes(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+  void process_get_index_names(int32_t seqid, apache::thrift::protocol::TProtocol* iprot, apache::thrift::protocol::TProtocol* oprot);
+ public:
+  ThriftHiveMetastoreProcessor(boost::shared_ptr<ThriftHiveMetastoreIf> iface) :
+    facebook::fb303::FacebookServiceProcessor(iface),
+    iface_(iface) {
+    processMap_["create_database"] = &ThriftHiveMetastoreProcessor::process_create_database;
+    processMap_["get_database"] = &ThriftHiveMetastoreProcessor::process_get_database;
+    processMap_["drop_database"] = &ThriftHiveMetastoreProcessor::process_drop_database;
+    processMap_["get_databases"] = &ThriftHiveMetastoreProcessor::process_get_databases;
+    processMap_["get_type"] = &ThriftHiveMetastoreProcessor::process_get_type;
+    processMap_["create_type"] = &ThriftHiveMetastoreProcessor::process_create_type;
+    processMap_["drop_type"] = &ThriftHiveMetastoreProcessor::process_drop_type;
+    processMap_["get_type_all"] = &ThriftHiveMetastoreProcessor::process_get_type_all;
+    processMap_["get_fields"] = &ThriftHiveMetastoreProcessor::process_get_fields;
+    processMap_["get_schema"] = &ThriftHiveMetastoreProcessor::process_get_schema;
+    processMap_["create_table"] = &ThriftHiveMetastoreProcessor::process_create_table;
+    processMap_["drop_table"] = &ThriftHiveMetastoreProcessor::process_drop_table;
+    processMap_["get_tables"] = &ThriftHiveMetastoreProcessor::process_get_tables;
+    processMap_["get_table"] = &ThriftHiveMetastoreProcessor::process_get_table;
+    processMap_["alter_table"] = &ThriftHiveMetastoreProcessor::process_alter_table;
+    processMap_["add_partition"] = &ThriftHiveMetastoreProcessor::process_add_partition;
+    processMap_["append_partition"] = &ThriftHiveMetastoreProcessor::process_append_partition;
+    processMap_["append_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_append_partition_by_name;
+    processMap_["drop_partition"] = &ThriftHiveMetastoreProcessor::process_drop_partition;
+    processMap_["drop_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_drop_partition_by_name;
+    processMap_["get_partition"] = &ThriftHiveMetastoreProcessor::process_get_partition;
+    processMap_["get_partition_by_name"] = &ThriftHiveMetastoreProcessor::process_get_partition_by_name;
+    processMap_["get_partitions"] = &ThriftHiveMetastoreProcessor::process_get_partitions;
+    processMap_["get_partition_names"] = &ThriftHiveMetastoreProcessor::process_get_partition_names;
+    processMap_["get_partitions_ps"] = &ThriftHiveMetastoreProcessor::process_get_partitions_ps;
+    processMap_["get_partition_names_ps"] = &ThriftHiveMetastoreProcessor::process_get_partition_names_ps;
+    processMap_["alter_partition"] = &ThriftHiveMetastoreProcessor::process_alter_partition;
+    processMap_["get_config_value"] = &ThriftHiveMetastoreProcessor::process_get_config_value;
+    processMap_["partition_name_to_vals"] = &ThriftHiveMetastoreProcessor::process_partition_name_to_vals;
+    processMap_["partition_name_to_spec"] = &ThriftHiveMetastoreProcessor::process_partition_name_to_spec;
+    processMap_["add_index"] = &ThriftHiveMetastoreProcessor::process_add_index;
+    processMap_["drop_index_by_name"] = &ThriftHiveMetastoreProcessor::process_drop_index_by_name;
+    processMap_["get_index_by_name"] = &ThriftHiveMetastoreProcessor::process_get_index_by_name;
+    processMap_["get_indexes"] = &ThriftHiveMetastoreProcessor::process_get_indexes;
+    processMap_["get_index_names"] = &ThriftHiveMetastoreProcessor::process_get_index_names;
+  }
+
+  virtual bool process(boost::shared_ptr<apache::thrift::protocol::TProtocol> piprot, boost::shared_ptr<apache::thrift::protocol::TProtocol> poprot);
+  virtual ~ThriftHiveMetastoreProcessor() {}
+};
+
+class ThriftHiveMetastoreMultiface : virtual public ThriftHiveMetastoreIf, public facebook::fb303::FacebookServiceMultiface {
+ public:
+  ThriftHiveMetastoreMultiface(std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> >& ifaces) : ifaces_(ifaces) {
+    std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> >::iterator iter;
+    for (iter = ifaces.begin(); iter != ifaces.end(); ++iter) {
+      facebook::fb303::FacebookServiceMultiface::add(*iter);
+    }
+  }
+  virtual ~ThriftHiveMetastoreMultiface() {}
+ protected:
+  std::vector<boost::shared_ptr<ThriftHiveMetastoreIf> > ifaces_;
+  ThriftHiveMetastoreMultiface() {}
+  void add(boost::shared_ptr<ThriftHiveMetastoreIf> iface) {
+    facebook::fb303::FacebookServiceMultiface::add(iface);
+    ifaces_.push_back(iface);
+  }
+ public:
+  bool create_database(const std::string& name, const std::string& description) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        return ifaces_[i]->create_database(name, description);
+      } else {
+        ifaces_[i]->create_database(name, description);
+      }
+    }
+  }
+
+  void get_database(Database& _return, const std::string& name) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->get_database(_return, name);
+        return;
+      } else {
+        ifaces_[i]->get_database(_return, name);
+      }
+    }
+  }
+
+  bool drop_database(const std::string& name) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        return ifaces_[i]->drop_database(name);
+      } else {
+        ifaces_[i]->drop_database(name);
+      }
+    }
+  }
+
+  void get_databases(std::vector<std::string> & _return) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->get_databases(_return);
         return;
       } else {
         ifaces_[i]->get_databases(_return);
@@ -3952,6 +4573,65 @@ class ThriftHiveMetastoreMultiface : vir
     }
   }
 
+  void add_index(Index& _return, const Index& new_index, const Table& index_table) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->add_index(_return, new_index, index_table);
+        return;
+      } else {
+        ifaces_[i]->add_index(_return, new_index, index_table);
+      }
+    }
+  }
+
+  bool drop_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name, const bool deleteData) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        return ifaces_[i]->drop_index_by_name(db_name, tbl_name, index_name, deleteData);
+      } else {
+        ifaces_[i]->drop_index_by_name(db_name, tbl_name, index_name, deleteData);
+      }
+    }
+  }
+
+  void get_index_by_name(Index& _return, const std::string& db_name, const std::string& tbl_name, const std::string& index_name) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->get_index_by_name(_return, db_name, tbl_name, index_name);
+        return;
+      } else {
+        ifaces_[i]->get_index_by_name(_return, db_name, tbl_name, index_name);
+      }
+    }
+  }
+
+  void get_indexes(std::vector<Index> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->get_indexes(_return, db_name, tbl_name, max_indexes);
+        return;
+      } else {
+        ifaces_[i]->get_indexes(_return, db_name, tbl_name, max_indexes);
+      }
+    }
+  }
+
+  void get_index_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) {
+    uint32_t sz = ifaces_.size();
+    for (uint32_t i = 0; i < sz; ++i) {
+      if (i == sz - 1) {
+        ifaces_[i]->get_index_names(_return, db_name, tbl_name, max_indexes);
+        return;
+      } else {
+        ifaces_[i]->get_index_names(_return, db_name, tbl_name, max_indexes);
+      }
+    }
+  }
+
 };
 
 }}} // namespace

Modified: hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
URL: http://svn.apache.org/viewvc/hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp?rev=980659&r1=980658&r2=980659&view=diff
==============================================================================
--- hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp (original)
+++ hadoop/hive/trunk/metastore/src/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp Fri Jul 30 06:40:04 2010
@@ -172,6 +172,31 @@ class ThriftHiveMetastoreHandler : virtu
     printf("partition_name_to_spec\n");
   }
 
+  void add_index(Index& _return, const Index& new_index, const Table& index_table) {
+    // Your implementation goes here
+    printf("add_index\n");
+  }
+
+  bool drop_index_by_name(const std::string& db_name, const std::string& tbl_name, const std::string& index_name, const bool deleteData) {
+    // Your implementation goes here
+    printf("drop_index_by_name\n");
+  }
+
+  void get_index_by_name(Index& _return, const std::string& db_name, const std::string& tbl_name, const std::string& index_name) {
+    // Your implementation goes here
+    printf("get_index_by_name\n");
+  }
+
+  void get_indexes(std::vector<Index> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) {
+    // Your implementation goes here
+    printf("get_indexes\n");
+  }
+
+  void get_index_names(std::vector<std::string> & _return, const std::string& db_name, const std::string& tbl_name, const int16_t max_indexes) {
+    // Your implementation goes here
+    printf("get_index_names\n");
+  }
+
 };
 
 int main(int argc, char **argv) {

Modified: hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.cpp
URL: http://svn.apache.org/viewvc/hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.cpp?rev=980659&r1=980658&r2=980659&view=diff
==============================================================================
--- hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.cpp (original)
+++ hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.cpp Fri Jul 30 06:40:04 2010
@@ -1111,8 +1111,8 @@ uint32_t Partition::write(apache::thrift
   return xfer;
 }
 
-const char* Index::ascii_fingerprint = "3163EDEDA2214D868610157908B1AB7A";
-const uint8_t Index::binary_fingerprint[16] = {0x31,0x63,0xED,0xED,0xA2,0x21,0x4D,0x86,0x86,0x10,0x15,0x79,0x08,0xB1,0xAB,0x7A};
+const char* Index::ascii_fingerprint = "5FEE4F7E28935B644F207D74459F6A29";
+const uint8_t Index::binary_fingerprint[16] = {0x5F,0xEE,0x4F,0x7E,0x28,0x93,0x5B,0x64,0x4F,0x20,0x7D,0x74,0x45,0x9F,0x6A,0x29};
 
 uint32_t Index::read(apache::thrift::protocol::TProtocol* iprot) {
 
@@ -1143,53 +1143,88 @@ uint32_t Index::read(apache::thrift::pro
         }
         break;
       case 2:
-        if (ftype == apache::thrift::protocol::T_I32) {
-          xfer += iprot->readI32(this->indexType);
-          this->__isset.indexType = true;
+        if (ftype == apache::thrift::protocol::T_STRING) {
+          xfer += iprot->readString(this->indexHandlerClass);
+          this->__isset.indexHandlerClass = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
       case 3:
         if (ftype == apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->tableName);
-          this->__isset.tableName = true;
+          xfer += iprot->readString(this->dbName);
+          this->__isset.dbName = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
       case 4:
         if (ftype == apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->dbName);
-          this->__isset.dbName = true;
+          xfer += iprot->readString(this->origTableName);
+          this->__isset.origTableName = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
       case 5:
-        if (ftype == apache::thrift::protocol::T_LIST) {
+        if (ftype == apache::thrift::protocol::T_I32) {
+          xfer += iprot->readI32(this->createTime);
+          this->__isset.createTime = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 6:
+        if (ftype == apache::thrift::protocol::T_I32) {
+          xfer += iprot->readI32(this->lastAccessTime);
+          this->__isset.lastAccessTime = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 7:
+        if (ftype == apache::thrift::protocol::T_STRING) {
+          xfer += iprot->readString(this->indexTableName);
+          this->__isset.indexTableName = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 8:
+        if (ftype == apache::thrift::protocol::T_STRUCT) {
+          xfer += this->sd.read(iprot);
+          this->__isset.sd = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 9:
+        if (ftype == apache::thrift::protocol::T_MAP) {
           {
-            this->colNames.clear();
+            this->parameters.clear();
             uint32_t _size68;
-            apache::thrift::protocol::TType _etype71;
-            iprot->readListBegin(_etype71, _size68);
-            this->colNames.resize(_size68);
+            apache::thrift::protocol::TType _ktype69;
+            apache::thrift::protocol::TType _vtype70;
+            iprot->readMapBegin(_ktype69, _vtype70, _size68);
             uint32_t _i72;
             for (_i72 = 0; _i72 < _size68; ++_i72)
             {
-              xfer += iprot->readString(this->colNames[_i72]);
+              std::string _key73;
+              xfer += iprot->readString(_key73);
+              std::string& _val74 = this->parameters[_key73];
+              xfer += iprot->readString(_val74);
             }
-            iprot->readListEnd();
+            iprot->readMapEnd();
           }
-          this->__isset.colNames = true;
+          this->__isset.parameters = true;
         } else {
           xfer += iprot->skip(ftype);
         }
         break;
-      case 6:
-        if (ftype == apache::thrift::protocol::T_STRING) {
-          xfer += iprot->readString(this->partName);
-          this->__isset.partName = true;
+      case 10:
+        if (ftype == apache::thrift::protocol::T_BOOL) {
+          xfer += iprot->readBool(this->deferredRebuild);
+          this->__isset.deferredRebuild = true;
         } else {
           xfer += iprot->skip(ftype);
         }
@@ -1212,28 +1247,41 @@ uint32_t Index::write(apache::thrift::pr
   xfer += oprot->writeFieldBegin("indexName", apache::thrift::protocol::T_STRING, 1);
   xfer += oprot->writeString(this->indexName);
   xfer += oprot->writeFieldEnd();
-  xfer += oprot->writeFieldBegin("indexType", apache::thrift::protocol::T_I32, 2);
-  xfer += oprot->writeI32(this->indexType);
-  xfer += oprot->writeFieldEnd();
-  xfer += oprot->writeFieldBegin("tableName", apache::thrift::protocol::T_STRING, 3);
-  xfer += oprot->writeString(this->tableName);
+  xfer += oprot->writeFieldBegin("indexHandlerClass", apache::thrift::protocol::T_STRING, 2);
+  xfer += oprot->writeString(this->indexHandlerClass);
   xfer += oprot->writeFieldEnd();
-  xfer += oprot->writeFieldBegin("dbName", apache::thrift::protocol::T_STRING, 4);
+  xfer += oprot->writeFieldBegin("dbName", apache::thrift::protocol::T_STRING, 3);
   xfer += oprot->writeString(this->dbName);
   xfer += oprot->writeFieldEnd();
-  xfer += oprot->writeFieldBegin("colNames", apache::thrift::protocol::T_LIST, 5);
+  xfer += oprot->writeFieldBegin("origTableName", apache::thrift::protocol::T_STRING, 4);
+  xfer += oprot->writeString(this->origTableName);
+  xfer += oprot->writeFieldEnd();
+  xfer += oprot->writeFieldBegin("createTime", apache::thrift::protocol::T_I32, 5);
+  xfer += oprot->writeI32(this->createTime);
+  xfer += oprot->writeFieldEnd();
+  xfer += oprot->writeFieldBegin("lastAccessTime", apache::thrift::protocol::T_I32, 6);
+  xfer += oprot->writeI32(this->lastAccessTime);
+  xfer += oprot->writeFieldEnd();
+  xfer += oprot->writeFieldBegin("indexTableName", apache::thrift::protocol::T_STRING, 7);
+  xfer += oprot->writeString(this->indexTableName);
+  xfer += oprot->writeFieldEnd();
+  xfer += oprot->writeFieldBegin("sd", apache::thrift::protocol::T_STRUCT, 8);
+  xfer += this->sd.write(oprot);
+  xfer += oprot->writeFieldEnd();
+  xfer += oprot->writeFieldBegin("parameters", apache::thrift::protocol::T_MAP, 9);
   {
-    xfer += oprot->writeListBegin(apache::thrift::protocol::T_STRING, this->colNames.size());
-    std::vector<std::string> ::const_iterator _iter73;
-    for (_iter73 = this->colNames.begin(); _iter73 != this->colNames.end(); ++_iter73)
+    xfer += oprot->writeMapBegin(apache::thrift::protocol::T_STRING, apache::thrift::protocol::T_STRING, this->parameters.size());
+    std::map<std::string, std::string> ::const_iterator _iter75;
+    for (_iter75 = this->parameters.begin(); _iter75 != this->parameters.end(); ++_iter75)
     {
-      xfer += oprot->writeString((*_iter73));
+      xfer += oprot->writeString(_iter75->first);
+      xfer += oprot->writeString(_iter75->second);
     }
-    xfer += oprot->writeListEnd();
+    xfer += oprot->writeMapEnd();
   }
   xfer += oprot->writeFieldEnd();
-  xfer += oprot->writeFieldBegin("partName", apache::thrift::protocol::T_STRING, 6);
-  xfer += oprot->writeString(this->partName);
+  xfer += oprot->writeFieldBegin("deferredRebuild", apache::thrift::protocol::T_BOOL, 10);
+  xfer += oprot->writeBool(this->deferredRebuild);
   xfer += oprot->writeFieldEnd();
   xfer += oprot->writeFieldStop();
   xfer += oprot->writeStructEnd();
@@ -1267,14 +1315,14 @@ uint32_t Schema::read(apache::thrift::pr
         if (ftype == apache::thrift::protocol::T_LIST) {
           {
             this->fieldSchemas.clear();
-            uint32_t _size74;
-            apache::thrift::protocol::TType _etype77;
-            iprot->readListBegin(_etype77, _size74);
-            this->fieldSchemas.resize(_size74);
-            uint32_t _i78;
-            for (_i78 = 0; _i78 < _size74; ++_i78)
+            uint32_t _size76;
+            apache::thrift::protocol::TType _etype79;
+            iprot->readListBegin(_etype79, _size76);
+            this->fieldSchemas.resize(_size76);
+            uint32_t _i80;
+            for (_i80 = 0; _i80 < _size76; ++_i80)
             {
-              xfer += this->fieldSchemas[_i78].read(iprot);
+              xfer += this->fieldSchemas[_i80].read(iprot);
             }
             iprot->readListEnd();
           }
@@ -1287,17 +1335,17 @@ uint32_t Schema::read(apache::thrift::pr
         if (ftype == apache::thrift::protocol::T_MAP) {
           {
             this->properties.clear();
-            uint32_t _size79;
-            apache::thrift::protocol::TType _ktype80;
-            apache::thrift::protocol::TType _vtype81;
-            iprot->readMapBegin(_ktype80, _vtype81, _size79);
-            uint32_t _i83;
-            for (_i83 = 0; _i83 < _size79; ++_i83)
+            uint32_t _size81;
+            apache::thrift::protocol::TType _ktype82;
+            apache::thrift::protocol::TType _vtype83;
+            iprot->readMapBegin(_ktype82, _vtype83, _size81);
+            uint32_t _i85;
+            for (_i85 = 0; _i85 < _size81; ++_i85)
             {
-              std::string _key84;
-              xfer += iprot->readString(_key84);
-              std::string& _val85 = this->properties[_key84];
-              xfer += iprot->readString(_val85);
+              std::string _key86;
+              xfer += iprot->readString(_key86);
+              std::string& _val87 = this->properties[_key86];
+              xfer += iprot->readString(_val87);
             }
             iprot->readMapEnd();
           }
@@ -1324,10 +1372,10 @@ uint32_t Schema::write(apache::thrift::p
   xfer += oprot->writeFieldBegin("fieldSchemas", apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(apache::thrift::protocol::T_STRUCT, this->fieldSchemas.size());
-    std::vector<FieldSchema> ::const_iterator _iter86;
-    for (_iter86 = this->fieldSchemas.begin(); _iter86 != this->fieldSchemas.end(); ++_iter86)
+    std::vector<FieldSchema> ::const_iterator _iter88;
+    for (_iter88 = this->fieldSchemas.begin(); _iter88 != this->fieldSchemas.end(); ++_iter88)
     {
-      xfer += (*_iter86).write(oprot);
+      xfer += (*_iter88).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }
@@ -1335,11 +1383,11 @@ uint32_t Schema::write(apache::thrift::p
   xfer += oprot->writeFieldBegin("properties", apache::thrift::protocol::T_MAP, 2);
   {
     xfer += oprot->writeMapBegin(apache::thrift::protocol::T_STRING, apache::thrift::protocol::T_STRING, this->properties.size());
-    std::map<std::string, std::string> ::const_iterator _iter87;
-    for (_iter87 = this->properties.begin(); _iter87 != this->properties.end(); ++_iter87)
+    std::map<std::string, std::string> ::const_iterator _iter89;
+    for (_iter89 = this->properties.begin(); _iter89 != this->properties.end(); ++_iter89)
     {
-      xfer += oprot->writeString(_iter87->first);
-      xfer += oprot->writeString(_iter87->second);
+      xfer += oprot->writeString(_iter89->first);
+      xfer += oprot->writeString(_iter89->second);
     }
     xfer += oprot->writeMapEnd();
   }

Modified: hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.h
URL: http://svn.apache.org/viewvc/hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.h?rev=980659&r1=980658&r2=980659&view=diff
==============================================================================
--- hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.h (original)
+++ hadoop/hive/trunk/metastore/src/gen-cpp/hive_metastore_types.h Fri Jul 30 06:40:04 2010
@@ -483,44 +483,60 @@ class Partition {
 class Index {
  public:
 
-  static const char* ascii_fingerprint; // = "3163EDEDA2214D868610157908B1AB7A";
-  static const uint8_t binary_fingerprint[16]; // = {0x31,0x63,0xED,0xED,0xA2,0x21,0x4D,0x86,0x86,0x10,0x15,0x79,0x08,0xB1,0xAB,0x7A};
+  static const char* ascii_fingerprint; // = "5FEE4F7E28935B644F207D74459F6A29";
+  static const uint8_t binary_fingerprint[16]; // = {0x5F,0xEE,0x4F,0x7E,0x28,0x93,0x5B,0x64,0x4F,0x20,0x7D,0x74,0x45,0x9F,0x6A,0x29};
 
-  Index() : indexName(""), indexType(0), tableName(""), dbName(""), partName("") {
+  Index() : indexName(""), indexHandlerClass(""), dbName(""), origTableName(""), createTime(0), lastAccessTime(0), indexTableName(""), deferredRebuild(0) {
   }
 
   virtual ~Index() throw() {}
 
   std::string indexName;
-  int32_t indexType;
-  std::string tableName;
+  std::string indexHandlerClass;
   std::string dbName;
-  std::vector<std::string>  colNames;
-  std::string partName;
+  std::string origTableName;
+  int32_t createTime;
+  int32_t lastAccessTime;
+  std::string indexTableName;
+  StorageDescriptor sd;
+  std::map<std::string, std::string>  parameters;
+  bool deferredRebuild;
 
   struct __isset {
-    __isset() : indexName(false), indexType(false), tableName(false), dbName(false), colNames(false), partName(false) {}
+    __isset() : indexName(false), indexHandlerClass(false), dbName(false), origTableName(false), createTime(false), lastAccessTime(false), indexTableName(false), sd(false), parameters(false), deferredRebuild(false) {}
     bool indexName;
-    bool indexType;
-    bool tableName;
+    bool indexHandlerClass;
     bool dbName;
-    bool colNames;
-    bool partName;
+    bool origTableName;
+    bool createTime;
+    bool lastAccessTime;
+    bool indexTableName;
+    bool sd;
+    bool parameters;
+    bool deferredRebuild;
   } __isset;
 
   bool operator == (const Index & rhs) const
   {
     if (!(indexName == rhs.indexName))
       return false;
-    if (!(indexType == rhs.indexType))
-      return false;
-    if (!(tableName == rhs.tableName))
+    if (!(indexHandlerClass == rhs.indexHandlerClass))
       return false;
     if (!(dbName == rhs.dbName))
       return false;
-    if (!(colNames == rhs.colNames))
+    if (!(origTableName == rhs.origTableName))
+      return false;
+    if (!(createTime == rhs.createTime))
+      return false;
+    if (!(lastAccessTime == rhs.lastAccessTime))
+      return false;
+    if (!(indexTableName == rhs.indexTableName))
+      return false;
+    if (!(sd == rhs.sd))
+      return false;
+    if (!(parameters == rhs.parameters))
       return false;
-    if (!(partName == rhs.partName))
+    if (!(deferredRebuild == rhs.deferredRebuild))
       return false;
     return true;
   }