You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by ha...@apache.org on 2014/03/30 20:40:46 UTC

svn commit: r1583186 [3/7] - in /hive/branches/branch-0.13: itests/hive-unit/src/test/java/org/apache/hadoop/hive/metastore/ metastore/if/ metastore/src/gen/thrift/gen-cpp/ metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ met...

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore.h Sun Mar 30 18:40:45 2014
@@ -120,6 +120,7 @@ class ThriftHiveMetastoreIf : virtual pu
   virtual void unlock(const UnlockRequest& rqst) = 0;
   virtual void show_locks(ShowLocksResponse& _return, const ShowLocksRequest& rqst) = 0;
   virtual void heartbeat(const HeartbeatRequest& ids) = 0;
+  virtual void heartbeat_txn_range(HeartbeatTxnRangeResponse& _return, const HeartbeatTxnRangeRequest& txns) = 0;
   virtual void compact(const CompactionRequest& rqst) = 0;
   virtual void show_compact(ShowCompactResponse& _return, const ShowCompactRequest& rqst) = 0;
 };
@@ -484,6 +485,9 @@ class ThriftHiveMetastoreNull : virtual 
   void heartbeat(const HeartbeatRequest& /* ids */) {
     return;
   }
+  void heartbeat_txn_range(HeartbeatTxnRangeResponse& /* _return */, const HeartbeatTxnRangeRequest& /* txns */) {
+    return;
+  }
   void compact(const CompactionRequest& /* rqst */) {
     return;
   }
@@ -14886,6 +14890,114 @@ class ThriftHiveMetastore_heartbeat_pres
 
 };
 
+typedef struct _ThriftHiveMetastore_heartbeat_txn_range_args__isset {
+  _ThriftHiveMetastore_heartbeat_txn_range_args__isset() : txns(false) {}
+  bool txns;
+} _ThriftHiveMetastore_heartbeat_txn_range_args__isset;
+
+class ThriftHiveMetastore_heartbeat_txn_range_args {
+ public:
+
+  ThriftHiveMetastore_heartbeat_txn_range_args() {
+  }
+
+  virtual ~ThriftHiveMetastore_heartbeat_txn_range_args() throw() {}
+
+  HeartbeatTxnRangeRequest txns;
+
+  _ThriftHiveMetastore_heartbeat_txn_range_args__isset __isset;
+
+  void __set_txns(const HeartbeatTxnRangeRequest& val) {
+    txns = val;
+  }
+
+  bool operator == (const ThriftHiveMetastore_heartbeat_txn_range_args & rhs) const
+  {
+    if (!(txns == rhs.txns))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_heartbeat_txn_range_args &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_heartbeat_txn_range_args & ) const;
+
+  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+
+class ThriftHiveMetastore_heartbeat_txn_range_pargs {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_heartbeat_txn_range_pargs() throw() {}
+
+  const HeartbeatTxnRangeRequest* txns;
+
+  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+typedef struct _ThriftHiveMetastore_heartbeat_txn_range_result__isset {
+  _ThriftHiveMetastore_heartbeat_txn_range_result__isset() : success(false) {}
+  bool success;
+} _ThriftHiveMetastore_heartbeat_txn_range_result__isset;
+
+class ThriftHiveMetastore_heartbeat_txn_range_result {
+ public:
+
+  ThriftHiveMetastore_heartbeat_txn_range_result() {
+  }
+
+  virtual ~ThriftHiveMetastore_heartbeat_txn_range_result() throw() {}
+
+  HeartbeatTxnRangeResponse success;
+
+  _ThriftHiveMetastore_heartbeat_txn_range_result__isset __isset;
+
+  void __set_success(const HeartbeatTxnRangeResponse& val) {
+    success = val;
+  }
+
+  bool operator == (const ThriftHiveMetastore_heartbeat_txn_range_result & rhs) const
+  {
+    if (!(success == rhs.success))
+      return false;
+    return true;
+  }
+  bool operator != (const ThriftHiveMetastore_heartbeat_txn_range_result &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const ThriftHiveMetastore_heartbeat_txn_range_result & ) const;
+
+  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+typedef struct _ThriftHiveMetastore_heartbeat_txn_range_presult__isset {
+  _ThriftHiveMetastore_heartbeat_txn_range_presult__isset() : success(false) {}
+  bool success;
+} _ThriftHiveMetastore_heartbeat_txn_range_presult__isset;
+
+class ThriftHiveMetastore_heartbeat_txn_range_presult {
+ public:
+
+
+  virtual ~ThriftHiveMetastore_heartbeat_txn_range_presult() throw() {}
+
+  HeartbeatTxnRangeResponse* success;
+
+  _ThriftHiveMetastore_heartbeat_txn_range_presult__isset __isset;
+
+  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
+
+};
+
 typedef struct _ThriftHiveMetastore_compact_args__isset {
   _ThriftHiveMetastore_compact_args__isset() : rqst(false) {}
   bool rqst;
@@ -15406,6 +15518,9 @@ class ThriftHiveMetastoreClient : virtua
   void heartbeat(const HeartbeatRequest& ids);
   void send_heartbeat(const HeartbeatRequest& ids);
   void recv_heartbeat();
+  void heartbeat_txn_range(HeartbeatTxnRangeResponse& _return, const HeartbeatTxnRangeRequest& txns);
+  void send_heartbeat_txn_range(const HeartbeatTxnRangeRequest& txns);
+  void recv_heartbeat_txn_range(HeartbeatTxnRangeResponse& _return);
   void compact(const CompactionRequest& rqst);
   void send_compact(const CompactionRequest& rqst);
   void recv_compact();
@@ -15526,6 +15641,7 @@ class ThriftHiveMetastoreProcessor : pub
   void process_unlock(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_show_locks(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_heartbeat(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
+  void process_heartbeat_txn_range(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_compact(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
   void process_show_compact(int32_t seqid, ::apache::thrift::protocol::TProtocol* iprot, ::apache::thrift::protocol::TProtocol* oprot, void* callContext);
  public:
@@ -15636,6 +15752,7 @@ class ThriftHiveMetastoreProcessor : pub
     processMap_["unlock"] = &ThriftHiveMetastoreProcessor::process_unlock;
     processMap_["show_locks"] = &ThriftHiveMetastoreProcessor::process_show_locks;
     processMap_["heartbeat"] = &ThriftHiveMetastoreProcessor::process_heartbeat;
+    processMap_["heartbeat_txn_range"] = &ThriftHiveMetastoreProcessor::process_heartbeat_txn_range;
     processMap_["compact"] = &ThriftHiveMetastoreProcessor::process_compact;
     processMap_["show_compact"] = &ThriftHiveMetastoreProcessor::process_show_compact;
   }
@@ -16667,6 +16784,16 @@ class ThriftHiveMetastoreMultiface : vir
     ifaces_[i]->heartbeat(ids);
   }
 
+  void heartbeat_txn_range(HeartbeatTxnRangeResponse& _return, const HeartbeatTxnRangeRequest& txns) {
+    size_t sz = ifaces_.size();
+    size_t i = 0;
+    for (; i < (sz - 1); ++i) {
+      ifaces_[i]->heartbeat_txn_range(_return, txns);
+    }
+    ifaces_[i]->heartbeat_txn_range(_return, txns);
+    return;
+  }
+
   void compact(const CompactionRequest& rqst) {
     size_t sz = ifaces_.size();
     size_t i = 0;

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/ThriftHiveMetastore_server.skeleton.cpp Sun Mar 30 18:40:45 2014
@@ -542,6 +542,11 @@ class ThriftHiveMetastoreHandler : virtu
     printf("heartbeat\n");
   }
 
+  void heartbeat_txn_range(HeartbeatTxnRangeResponse& _return, const HeartbeatTxnRangeRequest& txns) {
+    // Your implementation goes here
+    printf("heartbeat_txn_range\n");
+  }
+
   void compact(const CompactionRequest& rqst) {
     // Your implementation goes here
     printf("compact\n");

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.cpp Sun Mar 30 18:40:45 2014
@@ -7623,6 +7623,208 @@ void swap(HeartbeatRequest &a, Heartbeat
   swap(a.__isset, b.__isset);
 }
 
+const char* HeartbeatTxnRangeRequest::ascii_fingerprint = "F33135321253DAEB67B0E79E416CA831";
+const uint8_t HeartbeatTxnRangeRequest::binary_fingerprint[16] = {0xF3,0x31,0x35,0x32,0x12,0x53,0xDA,0xEB,0x67,0xB0,0xE7,0x9E,0x41,0x6C,0xA8,0x31};
+
+uint32_t HeartbeatTxnRangeRequest::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);
+
+  using ::apache::thrift::protocol::TProtocolException;
+
+  bool isset_min = false;
+  bool isset_max = false;
+
+  while (true)
+  {
+    xfer += iprot->readFieldBegin(fname, ftype, fid);
+    if (ftype == ::apache::thrift::protocol::T_STOP) {
+      break;
+    }
+    switch (fid)
+    {
+      case 1:
+        if (ftype == ::apache::thrift::protocol::T_I64) {
+          xfer += iprot->readI64(this->min);
+          isset_min = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 2:
+        if (ftype == ::apache::thrift::protocol::T_I64) {
+          xfer += iprot->readI64(this->max);
+          isset_max = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      default:
+        xfer += iprot->skip(ftype);
+        break;
+    }
+    xfer += iprot->readFieldEnd();
+  }
+
+  xfer += iprot->readStructEnd();
+
+  if (!isset_min)
+    throw TProtocolException(TProtocolException::INVALID_DATA);
+  if (!isset_max)
+    throw TProtocolException(TProtocolException::INVALID_DATA);
+  return xfer;
+}
+
+uint32_t HeartbeatTxnRangeRequest::write(::apache::thrift::protocol::TProtocol* oprot) const {
+  uint32_t xfer = 0;
+  xfer += oprot->writeStructBegin("HeartbeatTxnRangeRequest");
+
+  xfer += oprot->writeFieldBegin("min", ::apache::thrift::protocol::T_I64, 1);
+  xfer += oprot->writeI64(this->min);
+  xfer += oprot->writeFieldEnd();
+
+  xfer += oprot->writeFieldBegin("max", ::apache::thrift::protocol::T_I64, 2);
+  xfer += oprot->writeI64(this->max);
+  xfer += oprot->writeFieldEnd();
+
+  xfer += oprot->writeFieldStop();
+  xfer += oprot->writeStructEnd();
+  return xfer;
+}
+
+void swap(HeartbeatTxnRangeRequest &a, HeartbeatTxnRangeRequest &b) {
+  using ::std::swap;
+  swap(a.min, b.min);
+  swap(a.max, b.max);
+}
+
+const char* HeartbeatTxnRangeResponse::ascii_fingerprint = "33E49A70BD5C04262A0F407E3656E3CF";
+const uint8_t HeartbeatTxnRangeResponse::binary_fingerprint[16] = {0x33,0xE4,0x9A,0x70,0xBD,0x5C,0x04,0x26,0x2A,0x0F,0x40,0x7E,0x36,0x56,0xE3,0xCF};
+
+uint32_t HeartbeatTxnRangeResponse::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);
+
+  using ::apache::thrift::protocol::TProtocolException;
+
+  bool isset_aborted = false;
+  bool isset_nosuch = false;
+
+  while (true)
+  {
+    xfer += iprot->readFieldBegin(fname, ftype, fid);
+    if (ftype == ::apache::thrift::protocol::T_STOP) {
+      break;
+    }
+    switch (fid)
+    {
+      case 1:
+        if (ftype == ::apache::thrift::protocol::T_SET) {
+          {
+            this->aborted.clear();
+            uint32_t _size337;
+            ::apache::thrift::protocol::TType _etype340;
+            xfer += iprot->readSetBegin(_etype340, _size337);
+            uint32_t _i341;
+            for (_i341 = 0; _i341 < _size337; ++_i341)
+            {
+              int64_t _elem342;
+              xfer += iprot->readI64(_elem342);
+              this->aborted.insert(_elem342);
+            }
+            xfer += iprot->readSetEnd();
+          }
+          isset_aborted = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      case 2:
+        if (ftype == ::apache::thrift::protocol::T_SET) {
+          {
+            this->nosuch.clear();
+            uint32_t _size343;
+            ::apache::thrift::protocol::TType _etype346;
+            xfer += iprot->readSetBegin(_etype346, _size343);
+            uint32_t _i347;
+            for (_i347 = 0; _i347 < _size343; ++_i347)
+            {
+              int64_t _elem348;
+              xfer += iprot->readI64(_elem348);
+              this->nosuch.insert(_elem348);
+            }
+            xfer += iprot->readSetEnd();
+          }
+          isset_nosuch = true;
+        } else {
+          xfer += iprot->skip(ftype);
+        }
+        break;
+      default:
+        xfer += iprot->skip(ftype);
+        break;
+    }
+    xfer += iprot->readFieldEnd();
+  }
+
+  xfer += iprot->readStructEnd();
+
+  if (!isset_aborted)
+    throw TProtocolException(TProtocolException::INVALID_DATA);
+  if (!isset_nosuch)
+    throw TProtocolException(TProtocolException::INVALID_DATA);
+  return xfer;
+}
+
+uint32_t HeartbeatTxnRangeResponse::write(::apache::thrift::protocol::TProtocol* oprot) const {
+  uint32_t xfer = 0;
+  xfer += oprot->writeStructBegin("HeartbeatTxnRangeResponse");
+
+  xfer += oprot->writeFieldBegin("aborted", ::apache::thrift::protocol::T_SET, 1);
+  {
+    xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->aborted.size()));
+    std::set<int64_t> ::const_iterator _iter349;
+    for (_iter349 = this->aborted.begin(); _iter349 != this->aborted.end(); ++_iter349)
+    {
+      xfer += oprot->writeI64((*_iter349));
+    }
+    xfer += oprot->writeSetEnd();
+  }
+  xfer += oprot->writeFieldEnd();
+
+  xfer += oprot->writeFieldBegin("nosuch", ::apache::thrift::protocol::T_SET, 2);
+  {
+    xfer += oprot->writeSetBegin(::apache::thrift::protocol::T_I64, static_cast<uint32_t>(this->nosuch.size()));
+    std::set<int64_t> ::const_iterator _iter350;
+    for (_iter350 = this->nosuch.begin(); _iter350 != this->nosuch.end(); ++_iter350)
+    {
+      xfer += oprot->writeI64((*_iter350));
+    }
+    xfer += oprot->writeSetEnd();
+  }
+  xfer += oprot->writeFieldEnd();
+
+  xfer += oprot->writeFieldStop();
+  xfer += oprot->writeStructEnd();
+  return xfer;
+}
+
+void swap(HeartbeatTxnRangeResponse &a, HeartbeatTxnRangeResponse &b) {
+  using ::std::swap;
+  swap(a.aborted, b.aborted);
+  swap(a.nosuch, b.nosuch);
+}
+
 const char* CompactionRequest::ascii_fingerprint = "899FD1F339D8318D628687CC2CE2864B";
 const uint8_t CompactionRequest::binary_fingerprint[16] = {0x89,0x9F,0xD1,0xF3,0x39,0xD8,0x31,0x8D,0x62,0x86,0x87,0xCC,0x2C,0xE2,0x86,0x4B};
 
@@ -7675,9 +7877,9 @@ uint32_t CompactionRequest::read(::apach
         break;
       case 4:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast337;
-          xfer += iprot->readI32(ecast337);
-          this->type = (CompactionType::type)ecast337;
+          int32_t ecast351;
+          xfer += iprot->readI32(ecast351);
+          this->type = (CompactionType::type)ecast351;
           isset_type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -7852,9 +8054,9 @@ uint32_t ShowCompactResponseElement::rea
         break;
       case 4:
         if (ftype == ::apache::thrift::protocol::T_I32) {
-          int32_t ecast338;
-          xfer += iprot->readI32(ecast338);
-          this->type = (CompactionType::type)ecast338;
+          int32_t ecast352;
+          xfer += iprot->readI32(ecast352);
+          this->type = (CompactionType::type)ecast352;
           isset_type = true;
         } else {
           xfer += iprot->skip(ftype);
@@ -8001,14 +8203,14 @@ uint32_t ShowCompactResponse::read(::apa
         if (ftype == ::apache::thrift::protocol::T_LIST) {
           {
             this->compacts.clear();
-            uint32_t _size339;
-            ::apache::thrift::protocol::TType _etype342;
-            xfer += iprot->readListBegin(_etype342, _size339);
-            this->compacts.resize(_size339);
-            uint32_t _i343;
-            for (_i343 = 0; _i343 < _size339; ++_i343)
+            uint32_t _size353;
+            ::apache::thrift::protocol::TType _etype356;
+            xfer += iprot->readListBegin(_etype356, _size353);
+            this->compacts.resize(_size353);
+            uint32_t _i357;
+            for (_i357 = 0; _i357 < _size353; ++_i357)
             {
-              xfer += this->compacts[_i343].read(iprot);
+              xfer += this->compacts[_i357].read(iprot);
             }
             xfer += iprot->readListEnd();
           }
@@ -8038,10 +8240,10 @@ uint32_t ShowCompactResponse::write(::ap
   xfer += oprot->writeFieldBegin("compacts", ::apache::thrift::protocol::T_LIST, 1);
   {
     xfer += oprot->writeListBegin(::apache::thrift::protocol::T_STRUCT, static_cast<uint32_t>(this->compacts.size()));
-    std::vector<ShowCompactResponseElement> ::const_iterator _iter344;
-    for (_iter344 = this->compacts.begin(); _iter344 != this->compacts.end(); ++_iter344)
+    std::vector<ShowCompactResponseElement> ::const_iterator _iter358;
+    for (_iter358 = this->compacts.begin(); _iter358 != this->compacts.end(); ++_iter358)
     {
-      xfer += (*_iter344).write(oprot);
+      xfer += (*_iter358).write(oprot);
     }
     xfer += oprot->writeListEnd();
   }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-cpp/hive_metastore_types.h Sun Mar 30 18:40:45 2014
@@ -4083,6 +4083,94 @@ class HeartbeatRequest {
 
 void swap(HeartbeatRequest &a, HeartbeatRequest &b);
 
+
+class HeartbeatTxnRangeRequest {
+ public:
+
+  static const char* ascii_fingerprint; // = "F33135321253DAEB67B0E79E416CA831";
+  static const uint8_t binary_fingerprint[16]; // = {0xF3,0x31,0x35,0x32,0x12,0x53,0xDA,0xEB,0x67,0xB0,0xE7,0x9E,0x41,0x6C,0xA8,0x31};
+
+  HeartbeatTxnRangeRequest() : min(0), max(0) {
+  }
+
+  virtual ~HeartbeatTxnRangeRequest() throw() {}
+
+  int64_t min;
+  int64_t max;
+
+  void __set_min(const int64_t val) {
+    min = val;
+  }
+
+  void __set_max(const int64_t val) {
+    max = val;
+  }
+
+  bool operator == (const HeartbeatTxnRangeRequest & rhs) const
+  {
+    if (!(min == rhs.min))
+      return false;
+    if (!(max == rhs.max))
+      return false;
+    return true;
+  }
+  bool operator != (const HeartbeatTxnRangeRequest &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const HeartbeatTxnRangeRequest & ) const;
+
+  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+void swap(HeartbeatTxnRangeRequest &a, HeartbeatTxnRangeRequest &b);
+
+
+class HeartbeatTxnRangeResponse {
+ public:
+
+  static const char* ascii_fingerprint; // = "33E49A70BD5C04262A0F407E3656E3CF";
+  static const uint8_t binary_fingerprint[16]; // = {0x33,0xE4,0x9A,0x70,0xBD,0x5C,0x04,0x26,0x2A,0x0F,0x40,0x7E,0x36,0x56,0xE3,0xCF};
+
+  HeartbeatTxnRangeResponse() {
+  }
+
+  virtual ~HeartbeatTxnRangeResponse() throw() {}
+
+  std::set<int64_t>  aborted;
+  std::set<int64_t>  nosuch;
+
+  void __set_aborted(const std::set<int64_t> & val) {
+    aborted = val;
+  }
+
+  void __set_nosuch(const std::set<int64_t> & val) {
+    nosuch = val;
+  }
+
+  bool operator == (const HeartbeatTxnRangeResponse & rhs) const
+  {
+    if (!(aborted == rhs.aborted))
+      return false;
+    if (!(nosuch == rhs.nosuch))
+      return false;
+    return true;
+  }
+  bool operator != (const HeartbeatTxnRangeResponse &rhs) const {
+    return !(*this == rhs);
+  }
+
+  bool operator < (const HeartbeatTxnRangeResponse & ) const;
+
+  uint32_t read(::apache::thrift::protocol::TProtocol* iprot);
+  uint32_t write(::apache::thrift::protocol::TProtocol* oprot) const;
+
+};
+
+void swap(HeartbeatTxnRangeResponse &a, HeartbeatTxnRangeResponse &b);
+
 typedef struct _CompactionRequest__isset {
   _CompactionRequest__isset() : partitionname(false), runas(false) {}
   bool partitionname;

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsRequest.java Sun Mar 30 18:40:45 2014
@@ -704,7 +704,7 @@ public class AddPartitionsRequest implem
                 struct.parts = new ArrayList<Partition>(_list338.size);
                 for (int _i339 = 0; _i339 < _list338.size; ++_i339)
                 {
-                  Partition _elem340; // optional
+                  Partition _elem340; // required
                   _elem340 = new Partition();
                   _elem340.read(iprot);
                   struct.parts.add(_elem340);
@@ -824,7 +824,7 @@ public class AddPartitionsRequest implem
         struct.parts = new ArrayList<Partition>(_list343.size);
         for (int _i344 = 0; _i344 < _list343.size; ++_i344)
         {
-          Partition _elem345; // optional
+          Partition _elem345; // required
           _elem345 = new Partition();
           _elem345.read(iprot);
           struct.parts.add(_elem345);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AddPartitionsResult.java Sun Mar 30 18:40:45 2014
@@ -346,7 +346,7 @@ public class AddPartitionsResult impleme
                 struct.partitions = new ArrayList<Partition>(_list330.size);
                 for (int _i331 = 0; _i331 < _list330.size; ++_i331)
                 {
-                  Partition _elem332; // optional
+                  Partition _elem332; // required
                   _elem332 = new Partition();
                   _elem332.read(iprot);
                   struct.partitions.add(_elem332);
@@ -428,7 +428,7 @@ public class AddPartitionsResult impleme
           struct.partitions = new ArrayList<Partition>(_list335.size);
           for (int _i336 = 0; _i336 < _list335.size; ++_i336)
           {
-            Partition _elem337; // optional
+            Partition _elem337; // required
             _elem337 = new Partition();
             _elem337.read(iprot);
             struct.partitions.add(_elem337);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ColumnStatistics.java Sun Mar 30 18:40:45 2014
@@ -451,7 +451,7 @@ public class ColumnStatistics implements
                 struct.statsObj = new ArrayList<ColumnStatisticsObj>(_list236.size);
                 for (int _i237 = 0; _i237 < _list236.size; ++_i237)
                 {
-                  ColumnStatisticsObj _elem238; // optional
+                  ColumnStatisticsObj _elem238; // required
                   _elem238 = new ColumnStatisticsObj();
                   _elem238.read(iprot);
                   struct.statsObj.add(_elem238);
@@ -531,7 +531,7 @@ public class ColumnStatistics implements
         struct.statsObj = new ArrayList<ColumnStatisticsObj>(_list241.size);
         for (int _i242 = 0; _i242 < _list241.size; ++_i242)
         {
-          ColumnStatisticsObj _elem243; // optional
+          ColumnStatisticsObj _elem243; // required
           _elem243 = new ColumnStatisticsObj();
           _elem243.read(iprot);
           struct.statsObj.add(_elem243);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/DropPartitionsResult.java Sun Mar 30 18:40:45 2014
@@ -346,7 +346,7 @@ public class DropPartitionsResult implem
                 struct.partitions = new ArrayList<Partition>(_list346.size);
                 for (int _i347 = 0; _i347 < _list346.size; ++_i347)
                 {
-                  Partition _elem348; // optional
+                  Partition _elem348; // required
                   _elem348 = new Partition();
                   _elem348.read(iprot);
                   struct.partitions.add(_elem348);
@@ -428,7 +428,7 @@ public class DropPartitionsResult implem
           struct.partitions = new ArrayList<Partition>(_list351.size);
           for (int _i352 = 0; _i352 < _list351.size; ++_i352)
           {
-            Partition _elem353; // optional
+            Partition _elem353; // required
             _elem353 = new Partition();
             _elem353.read(iprot);
             struct.partitions.add(_elem353);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Function.java Sun Mar 30 18:40:45 2014
@@ -997,7 +997,7 @@ public class Function implements org.apa
                 struct.resourceUris = new ArrayList<ResourceUri>(_list370.size);
                 for (int _i371 = 0; _i371 < _list370.size; ++_i371)
                 {
-                  ResourceUri _elem372; // optional
+                  ResourceUri _elem372; // required
                   _elem372 = new ResourceUri();
                   _elem372.read(iprot);
                   struct.resourceUris.add(_elem372);
@@ -1180,7 +1180,7 @@ public class Function implements org.apa
           struct.resourceUris = new ArrayList<ResourceUri>(_list375.size);
           for (int _i376 = 0; _i376 < _list375.size; ++_i376)
           {
-            ResourceUri _elem377; // optional
+            ResourceUri _elem377; // required
             _elem377 = new ResourceUri();
             _elem377.read(iprot);
             struct.resourceUris.add(_elem377);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsInfoResponse.java Sun Mar 30 18:40:45 2014
@@ -447,7 +447,7 @@ public class GetOpenTxnsInfoResponse imp
                 struct.open_txns = new ArrayList<TxnInfo>(_list378.size);
                 for (int _i379 = 0; _i379 < _list378.size; ++_i379)
                 {
-                  TxnInfo _elem380; // optional
+                  TxnInfo _elem380; // required
                   _elem380 = new TxnInfo();
                   _elem380.read(iprot);
                   struct.open_txns.add(_elem380);
@@ -524,7 +524,7 @@ public class GetOpenTxnsInfoResponse imp
         struct.open_txns = new ArrayList<TxnInfo>(_list383.size);
         for (int _i384 = 0; _i384 < _list383.size; ++_i384)
         {
-          TxnInfo _elem385; // optional
+          TxnInfo _elem385; // required
           _elem385 = new TxnInfo();
           _elem385.read(iprot);
           struct.open_txns.add(_elem385);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetOpenTxnsResponse.java Sun Mar 30 18:40:45 2014
@@ -447,7 +447,7 @@ public class GetOpenTxnsResponse impleme
                 struct.open_txns = new HashSet<Long>(2*_set386.size);
                 for (int _i387 = 0; _i387 < _set386.size; ++_i387)
                 {
-                  long _elem388; // optional
+                  long _elem388; // required
                   _elem388 = iprot.readI64();
                   struct.open_txns.add(_elem388);
                 }
@@ -523,7 +523,7 @@ public class GetOpenTxnsResponse impleme
         struct.open_txns = new HashSet<Long>(2*_set391.size);
         for (int _i392 = 0; _i392 < _set391.size; ++_i392)
         {
-          long _elem393; // optional
+          long _elem393; // required
           _elem393 = iprot.readI64();
           struct.open_txns.add(_elem393);
         }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetPrincipalsInRoleResponse.java Sun Mar 30 18:40:45 2014
@@ -354,7 +354,7 @@ public class GetPrincipalsInRoleResponse
                 struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list86.size);
                 for (int _i87 = 0; _i87 < _list86.size; ++_i87)
                 {
-                  RolePrincipalGrant _elem88; // optional
+                  RolePrincipalGrant _elem88; // required
                   _elem88 = new RolePrincipalGrant();
                   _elem88.read(iprot);
                   struct.principalGrants.add(_elem88);
@@ -425,7 +425,7 @@ public class GetPrincipalsInRoleResponse
         struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list91.size);
         for (int _i92 = 0; _i92 < _list91.size; ++_i92)
         {
-          RolePrincipalGrant _elem93; // optional
+          RolePrincipalGrant _elem93; // required
           _elem93 = new RolePrincipalGrant();
           _elem93.read(iprot);
           struct.principalGrants.add(_elem93);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/GetRoleGrantsForPrincipalResponse.java Sun Mar 30 18:40:45 2014
@@ -354,7 +354,7 @@ public class GetRoleGrantsForPrincipalRe
                 struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list78.size);
                 for (int _i79 = 0; _i79 < _list78.size; ++_i79)
                 {
-                  RolePrincipalGrant _elem80; // optional
+                  RolePrincipalGrant _elem80; // required
                   _elem80 = new RolePrincipalGrant();
                   _elem80.read(iprot);
                   struct.principalGrants.add(_elem80);
@@ -425,7 +425,7 @@ public class GetRoleGrantsForPrincipalRe
         struct.principalGrants = new ArrayList<RolePrincipalGrant>(_list83.size);
         for (int _i84 = 0; _i84 < _list83.size; ++_i84)
         {
-          RolePrincipalGrant _elem85; // optional
+          RolePrincipalGrant _elem85; // required
           _elem85 = new RolePrincipalGrant();
           _elem85.read(iprot);
           struct.principalGrants.add(_elem85);

Added: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java?rev=1583186&view=auto
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java (added)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeRequest.java Sun Mar 30 18:40:45 2014
@@ -0,0 +1,478 @@
+/**
+ * Autogenerated by Thrift Compiler (0.9.0)
+ *
+ * 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;
+
+import org.apache.thrift.scheme.TupleScheme;
+import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
+import java.util.List;
+import java.util.ArrayList;
+import java.util.Map;
+import java.util.HashMap;
+import java.util.EnumMap;
+import java.util.Set;
+import java.util.HashSet;
+import java.util.EnumSet;
+import java.util.Collections;
+import java.util.BitSet;
+import java.nio.ByteBuffer;
+import java.util.Arrays;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class HeartbeatTxnRangeRequest implements org.apache.thrift.TBase<HeartbeatTxnRangeRequest, HeartbeatTxnRangeRequest._Fields>, java.io.Serializable, Cloneable {
+  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);
+  private static final org.apache.thrift.protocol.TField MAX_FIELD_DESC = new org.apache.thrift.protocol.TField("max", org.apache.thrift.protocol.TType.I64, (short)2);
+
+  private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
+  static {
+    schemes.put(StandardScheme.class, new HeartbeatTxnRangeRequestStandardSchemeFactory());
+    schemes.put(TupleScheme.class, new HeartbeatTxnRangeRequestTupleSchemeFactory());
+  }
+
+  private long min; // required
+  private long max; // required
+
+  /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    MIN((short)1, "min"),
+    MAX((short)2, "max");
+
+    private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
+
+    static {
+      for (_Fields field : EnumSet.allOf(_Fields.class)) {
+        byName.put(field.getFieldName(), field);
+      }
+    }
+
+    /**
+     * Find the _Fields constant that matches fieldId, or null if its not found.
+     */
+    public static _Fields findByThriftId(int fieldId) {
+      switch(fieldId) {
+        case 1: // MIN
+          return MIN;
+        case 2: // MAX
+          return MAX;
+        default:
+          return null;
+      }
+    }
+
+    /**
+     * Find the _Fields constant that matches fieldId, throwing an exception
+     * if it is not found.
+     */
+    public static _Fields findByThriftIdOrThrow(int fieldId) {
+      _Fields fields = findByThriftId(fieldId);
+      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
+      return fields;
+    }
+
+    /**
+     * Find the _Fields constant that matches name, or null if its not found.
+     */
+    public static _Fields findByName(String name) {
+      return byName.get(name);
+    }
+
+    private final short _thriftId;
+    private final String _fieldName;
+
+    _Fields(short thriftId, String fieldName) {
+      _thriftId = thriftId;
+      _fieldName = fieldName;
+    }
+
+    public short getThriftFieldId() {
+      return _thriftId;
+    }
+
+    public String getFieldName() {
+      return _fieldName;
+    }
+  }
+
+  // isset id assignments
+  private static final int __MIN_ISSET_ID = 0;
+  private static final int __MAX_ISSET_ID = 1;
+  private byte __isset_bitfield = 0;
+  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);
+    tmpMap.put(_Fields.MIN, new org.apache.thrift.meta_data.FieldMetaData("min", org.apache.thrift.TFieldRequirementType.REQUIRED, 
+        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64)));
+    tmpMap.put(_Fields.MAX, new org.apache.thrift.meta_data.FieldMetaData("max", org.apache.thrift.TFieldRequirementType.REQUIRED, 
+        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64)));
+    metaDataMap = Collections.unmodifiableMap(tmpMap);
+    org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(HeartbeatTxnRangeRequest.class, metaDataMap);
+  }
+
+  public HeartbeatTxnRangeRequest() {
+  }
+
+  public HeartbeatTxnRangeRequest(
+    long min,
+    long max)
+  {
+    this();
+    this.min = min;
+    setMinIsSet(true);
+    this.max = max;
+    setMaxIsSet(true);
+  }
+
+  /**
+   * Performs a deep copy on <i>other</i>.
+   */
+  public HeartbeatTxnRangeRequest(HeartbeatTxnRangeRequest other) {
+    __isset_bitfield = other.__isset_bitfield;
+    this.min = other.min;
+    this.max = other.max;
+  }
+
+  public HeartbeatTxnRangeRequest deepCopy() {
+    return new HeartbeatTxnRangeRequest(this);
+  }
+
+  @Override
+  public void clear() {
+    setMinIsSet(false);
+    this.min = 0;
+    setMaxIsSet(false);
+    this.max = 0;
+  }
+
+  public long getMin() {
+    return this.min;
+  }
+
+  public void setMin(long min) {
+    this.min = min;
+    setMinIsSet(true);
+  }
+
+  public void unsetMin() {
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __MIN_ISSET_ID);
+  }
+
+  /** Returns true if field min is set (has been assigned a value) and false otherwise */
+  public boolean isSetMin() {
+    return EncodingUtils.testBit(__isset_bitfield, __MIN_ISSET_ID);
+  }
+
+  public void setMinIsSet(boolean value) {
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __MIN_ISSET_ID, value);
+  }
+
+  public long getMax() {
+    return this.max;
+  }
+
+  public void setMax(long max) {
+    this.max = max;
+    setMaxIsSet(true);
+  }
+
+  public void unsetMax() {
+    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __MAX_ISSET_ID);
+  }
+
+  /** Returns true if field max is set (has been assigned a value) and false otherwise */
+  public boolean isSetMax() {
+    return EncodingUtils.testBit(__isset_bitfield, __MAX_ISSET_ID);
+  }
+
+  public void setMaxIsSet(boolean value) {
+    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __MAX_ISSET_ID, value);
+  }
+
+  public void setFieldValue(_Fields field, Object value) {
+    switch (field) {
+    case MIN:
+      if (value == null) {
+        unsetMin();
+      } else {
+        setMin((Long)value);
+      }
+      break;
+
+    case MAX:
+      if (value == null) {
+        unsetMax();
+      } else {
+        setMax((Long)value);
+      }
+      break;
+
+    }
+  }
+
+  public Object getFieldValue(_Fields field) {
+    switch (field) {
+    case MIN:
+      return Long.valueOf(getMin());
+
+    case MAX:
+      return Long.valueOf(getMax());
+
+    }
+    throw new IllegalStateException();
+  }
+
+  /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
+  public boolean isSet(_Fields field) {
+    if (field == null) {
+      throw new IllegalArgumentException();
+    }
+
+    switch (field) {
+    case MIN:
+      return isSetMin();
+    case MAX:
+      return isSetMax();
+    }
+    throw new IllegalStateException();
+  }
+
+  @Override
+  public boolean equals(Object that) {
+    if (that == null)
+      return false;
+    if (that instanceof HeartbeatTxnRangeRequest)
+      return this.equals((HeartbeatTxnRangeRequest)that);
+    return false;
+  }
+
+  public boolean equals(HeartbeatTxnRangeRequest that) {
+    if (that == null)
+      return false;
+
+    boolean this_present_min = true;
+    boolean that_present_min = true;
+    if (this_present_min || that_present_min) {
+      if (!(this_present_min && that_present_min))
+        return false;
+      if (this.min != that.min)
+        return false;
+    }
+
+    boolean this_present_max = true;
+    boolean that_present_max = true;
+    if (this_present_max || that_present_max) {
+      if (!(this_present_max && that_present_max))
+        return false;
+      if (this.max != that.max)
+        return false;
+    }
+
+    return true;
+  }
+
+  @Override
+  public int hashCode() {
+    HashCodeBuilder builder = new HashCodeBuilder();
+
+    boolean present_min = true;
+    builder.append(present_min);
+    if (present_min)
+      builder.append(min);
+
+    boolean present_max = true;
+    builder.append(present_max);
+    if (present_max)
+      builder.append(max);
+
+    return builder.toHashCode();
+  }
+
+  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());
+    if (lastComparison != 0) {
+      return lastComparison;
+    }
+    if (isSetMin()) {
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.min, typedOther.min);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+    }
+    lastComparison = Boolean.valueOf(isSetMax()).compareTo(typedOther.isSetMax());
+    if (lastComparison != 0) {
+      return lastComparison;
+    }
+    if (isSetMax()) {
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.max, typedOther.max);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+    }
+    return 0;
+  }
+
+  public _Fields fieldForId(int fieldId) {
+    return _Fields.findByThriftId(fieldId);
+  }
+
+  public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
+    schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
+  }
+
+  public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
+    schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
+  }
+
+  @Override
+  public String toString() {
+    StringBuilder sb = new StringBuilder("HeartbeatTxnRangeRequest(");
+    boolean first = true;
+
+    sb.append("min:");
+    sb.append(this.min);
+    first = false;
+    if (!first) sb.append(", ");
+    sb.append("max:");
+    sb.append(this.max);
+    first = false;
+    sb.append(")");
+    return sb.toString();
+  }
+
+  public void validate() throws org.apache.thrift.TException {
+    // check for required fields
+    if (!isSetMin()) {
+      throw new org.apache.thrift.protocol.TProtocolException("Required field 'min' is unset! Struct:" + toString());
+    }
+
+    if (!isSetMax()) {
+      throw new org.apache.thrift.protocol.TProtocolException("Required field 'max' is unset! Struct:" + toString());
+    }
+
+    // check for sub-struct validity
+  }
+
+  private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
+    try {
+      write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
+    } catch (org.apache.thrift.TException te) {
+      throw new java.io.IOException(te);
+    }
+  }
+
+  private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
+    try {
+      // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
+      __isset_bitfield = 0;
+      read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
+    } catch (org.apache.thrift.TException te) {
+      throw new java.io.IOException(te);
+    }
+  }
+
+  private static class HeartbeatTxnRangeRequestStandardSchemeFactory implements SchemeFactory {
+    public HeartbeatTxnRangeRequestStandardScheme getScheme() {
+      return new HeartbeatTxnRangeRequestStandardScheme();
+    }
+  }
+
+  private static class HeartbeatTxnRangeRequestStandardScheme extends StandardScheme<HeartbeatTxnRangeRequest> {
+
+    public void read(org.apache.thrift.protocol.TProtocol iprot, HeartbeatTxnRangeRequest struct) throws org.apache.thrift.TException {
+      org.apache.thrift.protocol.TField schemeField;
+      iprot.readStructBegin();
+      while (true)
+      {
+        schemeField = iprot.readFieldBegin();
+        if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
+          break;
+        }
+        switch (schemeField.id) {
+          case 1: // MIN
+            if (schemeField.type == org.apache.thrift.protocol.TType.I64) {
+              struct.min = iprot.readI64();
+              struct.setMinIsSet(true);
+            } else { 
+              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+            }
+            break;
+          case 2: // MAX
+            if (schemeField.type == org.apache.thrift.protocol.TType.I64) {
+              struct.max = iprot.readI64();
+              struct.setMaxIsSet(true);
+            } else { 
+              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+            }
+            break;
+          default:
+            org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+        }
+        iprot.readFieldEnd();
+      }
+      iprot.readStructEnd();
+      struct.validate();
+    }
+
+    public void write(org.apache.thrift.protocol.TProtocol oprot, HeartbeatTxnRangeRequest struct) throws org.apache.thrift.TException {
+      struct.validate();
+
+      oprot.writeStructBegin(STRUCT_DESC);
+      oprot.writeFieldBegin(MIN_FIELD_DESC);
+      oprot.writeI64(struct.min);
+      oprot.writeFieldEnd();
+      oprot.writeFieldBegin(MAX_FIELD_DESC);
+      oprot.writeI64(struct.max);
+      oprot.writeFieldEnd();
+      oprot.writeFieldStop();
+      oprot.writeStructEnd();
+    }
+
+  }
+
+  private static class HeartbeatTxnRangeRequestTupleSchemeFactory implements SchemeFactory {
+    public HeartbeatTxnRangeRequestTupleScheme getScheme() {
+      return new HeartbeatTxnRangeRequestTupleScheme();
+    }
+  }
+
+  private static class HeartbeatTxnRangeRequestTupleScheme extends TupleScheme<HeartbeatTxnRangeRequest> {
+
+    @Override
+    public void write(org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeRequest struct) throws org.apache.thrift.TException {
+      TTupleProtocol oprot = (TTupleProtocol) prot;
+      oprot.writeI64(struct.min);
+      oprot.writeI64(struct.max);
+    }
+
+    @Override
+    public void read(org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeRequest struct) throws org.apache.thrift.TException {
+      TTupleProtocol iprot = (TTupleProtocol) prot;
+      struct.min = iprot.readI64();
+      struct.setMinIsSet(true);
+      struct.max = iprot.readI64();
+      struct.setMaxIsSet(true);
+    }
+  }
+
+}
+

Added: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java?rev=1583186&view=auto
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java (added)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HeartbeatTxnRangeResponse.java Sun Mar 30 18:40:45 2014
@@ -0,0 +1,590 @@
+/**
+ * Autogenerated by Thrift Compiler (0.9.0)
+ *
+ * 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;
+
+import org.apache.thrift.scheme.TupleScheme;
+import org.apache.thrift.protocol.TTupleProtocol;
+import org.apache.thrift.protocol.TProtocolException;
+import org.apache.thrift.EncodingUtils;
+import org.apache.thrift.TException;
+import java.util.List;
+import java.util.ArrayList;
+import java.util.Map;
+import java.util.HashMap;
+import java.util.EnumMap;
+import java.util.Set;
+import java.util.HashSet;
+import java.util.EnumSet;
+import java.util.Collections;
+import java.util.BitSet;
+import java.nio.ByteBuffer;
+import java.util.Arrays;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+public class HeartbeatTxnRangeResponse implements org.apache.thrift.TBase<HeartbeatTxnRangeResponse, HeartbeatTxnRangeResponse._Fields>, java.io.Serializable, Cloneable {
+  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);
+  private static final org.apache.thrift.protocol.TField NOSUCH_FIELD_DESC = new org.apache.thrift.protocol.TField("nosuch", org.apache.thrift.protocol.TType.SET, (short)2);
+
+  private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
+  static {
+    schemes.put(StandardScheme.class, new HeartbeatTxnRangeResponseStandardSchemeFactory());
+    schemes.put(TupleScheme.class, new HeartbeatTxnRangeResponseTupleSchemeFactory());
+  }
+
+  private Set<Long> aborted; // required
+  private Set<Long> nosuch; // required
+
+  /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
+  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
+    ABORTED((short)1, "aborted"),
+    NOSUCH((short)2, "nosuch");
+
+    private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
+
+    static {
+      for (_Fields field : EnumSet.allOf(_Fields.class)) {
+        byName.put(field.getFieldName(), field);
+      }
+    }
+
+    /**
+     * Find the _Fields constant that matches fieldId, or null if its not found.
+     */
+    public static _Fields findByThriftId(int fieldId) {
+      switch(fieldId) {
+        case 1: // ABORTED
+          return ABORTED;
+        case 2: // NOSUCH
+          return NOSUCH;
+        default:
+          return null;
+      }
+    }
+
+    /**
+     * Find the _Fields constant that matches fieldId, throwing an exception
+     * if it is not found.
+     */
+    public static _Fields findByThriftIdOrThrow(int fieldId) {
+      _Fields fields = findByThriftId(fieldId);
+      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
+      return fields;
+    }
+
+    /**
+     * Find the _Fields constant that matches name, or null if its not found.
+     */
+    public static _Fields findByName(String name) {
+      return byName.get(name);
+    }
+
+    private final short _thriftId;
+    private final String _fieldName;
+
+    _Fields(short thriftId, String fieldName) {
+      _thriftId = thriftId;
+      _fieldName = fieldName;
+    }
+
+    public short getThriftFieldId() {
+      return _thriftId;
+    }
+
+    public String getFieldName() {
+      return _fieldName;
+    }
+  }
+
+  // isset id assignments
+  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);
+    tmpMap.put(_Fields.ABORTED, new org.apache.thrift.meta_data.FieldMetaData("aborted", org.apache.thrift.TFieldRequirementType.REQUIRED, 
+        new org.apache.thrift.meta_data.SetMetaData(org.apache.thrift.protocol.TType.SET, 
+            new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))));
+    tmpMap.put(_Fields.NOSUCH, new org.apache.thrift.meta_data.FieldMetaData("nosuch", org.apache.thrift.TFieldRequirementType.REQUIRED, 
+        new org.apache.thrift.meta_data.SetMetaData(org.apache.thrift.protocol.TType.SET, 
+            new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64))));
+    metaDataMap = Collections.unmodifiableMap(tmpMap);
+    org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(HeartbeatTxnRangeResponse.class, metaDataMap);
+  }
+
+  public HeartbeatTxnRangeResponse() {
+  }
+
+  public HeartbeatTxnRangeResponse(
+    Set<Long> aborted,
+    Set<Long> nosuch)
+  {
+    this();
+    this.aborted = aborted;
+    this.nosuch = nosuch;
+  }
+
+  /**
+   * Performs a deep copy on <i>other</i>.
+   */
+  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);
+      }
+      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);
+      }
+      this.nosuch = __this__nosuch;
+    }
+  }
+
+  public HeartbeatTxnRangeResponse deepCopy() {
+    return new HeartbeatTxnRangeResponse(this);
+  }
+
+  @Override
+  public void clear() {
+    this.aborted = null;
+    this.nosuch = null;
+  }
+
+  public int getAbortedSize() {
+    return (this.aborted == null) ? 0 : this.aborted.size();
+  }
+
+  public java.util.Iterator<Long> getAbortedIterator() {
+    return (this.aborted == null) ? null : this.aborted.iterator();
+  }
+
+  public void addToAborted(long elem) {
+    if (this.aborted == null) {
+      this.aborted = new HashSet<Long>();
+    }
+    this.aborted.add(elem);
+  }
+
+  public Set<Long> getAborted() {
+    return this.aborted;
+  }
+
+  public void setAborted(Set<Long> aborted) {
+    this.aborted = aborted;
+  }
+
+  public void unsetAborted() {
+    this.aborted = null;
+  }
+
+  /** Returns true if field aborted is set (has been assigned a value) and false otherwise */
+  public boolean isSetAborted() {
+    return this.aborted != null;
+  }
+
+  public void setAbortedIsSet(boolean value) {
+    if (!value) {
+      this.aborted = null;
+    }
+  }
+
+  public int getNosuchSize() {
+    return (this.nosuch == null) ? 0 : this.nosuch.size();
+  }
+
+  public java.util.Iterator<Long> getNosuchIterator() {
+    return (this.nosuch == null) ? null : this.nosuch.iterator();
+  }
+
+  public void addToNosuch(long elem) {
+    if (this.nosuch == null) {
+      this.nosuch = new HashSet<Long>();
+    }
+    this.nosuch.add(elem);
+  }
+
+  public Set<Long> getNosuch() {
+    return this.nosuch;
+  }
+
+  public void setNosuch(Set<Long> nosuch) {
+    this.nosuch = nosuch;
+  }
+
+  public void unsetNosuch() {
+    this.nosuch = null;
+  }
+
+  /** Returns true if field nosuch is set (has been assigned a value) and false otherwise */
+  public boolean isSetNosuch() {
+    return this.nosuch != null;
+  }
+
+  public void setNosuchIsSet(boolean value) {
+    if (!value) {
+      this.nosuch = null;
+    }
+  }
+
+  public void setFieldValue(_Fields field, Object value) {
+    switch (field) {
+    case ABORTED:
+      if (value == null) {
+        unsetAborted();
+      } else {
+        setAborted((Set<Long>)value);
+      }
+      break;
+
+    case NOSUCH:
+      if (value == null) {
+        unsetNosuch();
+      } else {
+        setNosuch((Set<Long>)value);
+      }
+      break;
+
+    }
+  }
+
+  public Object getFieldValue(_Fields field) {
+    switch (field) {
+    case ABORTED:
+      return getAborted();
+
+    case NOSUCH:
+      return getNosuch();
+
+    }
+    throw new IllegalStateException();
+  }
+
+  /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
+  public boolean isSet(_Fields field) {
+    if (field == null) {
+      throw new IllegalArgumentException();
+    }
+
+    switch (field) {
+    case ABORTED:
+      return isSetAborted();
+    case NOSUCH:
+      return isSetNosuch();
+    }
+    throw new IllegalStateException();
+  }
+
+  @Override
+  public boolean equals(Object that) {
+    if (that == null)
+      return false;
+    if (that instanceof HeartbeatTxnRangeResponse)
+      return this.equals((HeartbeatTxnRangeResponse)that);
+    return false;
+  }
+
+  public boolean equals(HeartbeatTxnRangeResponse that) {
+    if (that == null)
+      return false;
+
+    boolean this_present_aborted = true && this.isSetAborted();
+    boolean that_present_aborted = true && that.isSetAborted();
+    if (this_present_aborted || that_present_aborted) {
+      if (!(this_present_aborted && that_present_aborted))
+        return false;
+      if (!this.aborted.equals(that.aborted))
+        return false;
+    }
+
+    boolean this_present_nosuch = true && this.isSetNosuch();
+    boolean that_present_nosuch = true && that.isSetNosuch();
+    if (this_present_nosuch || that_present_nosuch) {
+      if (!(this_present_nosuch && that_present_nosuch))
+        return false;
+      if (!this.nosuch.equals(that.nosuch))
+        return false;
+    }
+
+    return true;
+  }
+
+  @Override
+  public int hashCode() {
+    HashCodeBuilder builder = new HashCodeBuilder();
+
+    boolean present_aborted = true && (isSetAborted());
+    builder.append(present_aborted);
+    if (present_aborted)
+      builder.append(aborted);
+
+    boolean present_nosuch = true && (isSetNosuch());
+    builder.append(present_nosuch);
+    if (present_nosuch)
+      builder.append(nosuch);
+
+    return builder.toHashCode();
+  }
+
+  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());
+    if (lastComparison != 0) {
+      return lastComparison;
+    }
+    if (isSetAborted()) {
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.aborted, typedOther.aborted);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+    }
+    lastComparison = Boolean.valueOf(isSetNosuch()).compareTo(typedOther.isSetNosuch());
+    if (lastComparison != 0) {
+      return lastComparison;
+    }
+    if (isSetNosuch()) {
+      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.nosuch, typedOther.nosuch);
+      if (lastComparison != 0) {
+        return lastComparison;
+      }
+    }
+    return 0;
+  }
+
+  public _Fields fieldForId(int fieldId) {
+    return _Fields.findByThriftId(fieldId);
+  }
+
+  public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
+    schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
+  }
+
+  public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
+    schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
+  }
+
+  @Override
+  public String toString() {
+    StringBuilder sb = new StringBuilder("HeartbeatTxnRangeResponse(");
+    boolean first = true;
+
+    sb.append("aborted:");
+    if (this.aborted == null) {
+      sb.append("null");
+    } else {
+      sb.append(this.aborted);
+    }
+    first = false;
+    if (!first) sb.append(", ");
+    sb.append("nosuch:");
+    if (this.nosuch == null) {
+      sb.append("null");
+    } else {
+      sb.append(this.nosuch);
+    }
+    first = false;
+    sb.append(")");
+    return sb.toString();
+  }
+
+  public void validate() throws org.apache.thrift.TException {
+    // check for required fields
+    if (!isSetAborted()) {
+      throw new org.apache.thrift.protocol.TProtocolException("Required field 'aborted' is unset! Struct:" + toString());
+    }
+
+    if (!isSetNosuch()) {
+      throw new org.apache.thrift.protocol.TProtocolException("Required field 'nosuch' is unset! Struct:" + toString());
+    }
+
+    // check for sub-struct validity
+  }
+
+  private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
+    try {
+      write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
+    } catch (org.apache.thrift.TException te) {
+      throw new java.io.IOException(te);
+    }
+  }
+
+  private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
+    try {
+      read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
+    } catch (org.apache.thrift.TException te) {
+      throw new java.io.IOException(te);
+    }
+  }
+
+  private static class HeartbeatTxnRangeResponseStandardSchemeFactory implements SchemeFactory {
+    public HeartbeatTxnRangeResponseStandardScheme getScheme() {
+      return new HeartbeatTxnRangeResponseStandardScheme();
+    }
+  }
+
+  private static class HeartbeatTxnRangeResponseStandardScheme extends StandardScheme<HeartbeatTxnRangeResponse> {
+
+    public void read(org.apache.thrift.protocol.TProtocol iprot, HeartbeatTxnRangeResponse struct) throws org.apache.thrift.TException {
+      org.apache.thrift.protocol.TField schemeField;
+      iprot.readStructBegin();
+      while (true)
+      {
+        schemeField = iprot.readFieldBegin();
+        if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
+          break;
+        }
+        switch (schemeField.id) {
+          case 1: // ABORTED
+            if (schemeField.type == org.apache.thrift.protocol.TType.SET) {
+              {
+                org.apache.thrift.protocol.TSet _set418 = iprot.readSetBegin();
+                struct.aborted = new HashSet<Long>(2*_set418.size);
+                for (int _i419 = 0; _i419 < _set418.size; ++_i419)
+                {
+                  long _elem420; // required
+                  _elem420 = iprot.readI64();
+                  struct.aborted.add(_elem420);
+                }
+                iprot.readSetEnd();
+              }
+              struct.setAbortedIsSet(true);
+            } else { 
+              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+            }
+            break;
+          case 2: // NOSUCH
+            if (schemeField.type == org.apache.thrift.protocol.TType.SET) {
+              {
+                org.apache.thrift.protocol.TSet _set421 = iprot.readSetBegin();
+                struct.nosuch = new HashSet<Long>(2*_set421.size);
+                for (int _i422 = 0; _i422 < _set421.size; ++_i422)
+                {
+                  long _elem423; // required
+                  _elem423 = iprot.readI64();
+                  struct.nosuch.add(_elem423);
+                }
+                iprot.readSetEnd();
+              }
+              struct.setNosuchIsSet(true);
+            } else { 
+              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+            }
+            break;
+          default:
+            org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
+        }
+        iprot.readFieldEnd();
+      }
+      iprot.readStructEnd();
+      struct.validate();
+    }
+
+    public void write(org.apache.thrift.protocol.TProtocol oprot, HeartbeatTxnRangeResponse struct) throws org.apache.thrift.TException {
+      struct.validate();
+
+      oprot.writeStructBegin(STRUCT_DESC);
+      if (struct.aborted != null) {
+        oprot.writeFieldBegin(ABORTED_FIELD_DESC);
+        {
+          oprot.writeSetBegin(new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, struct.aborted.size()));
+          for (long _iter424 : struct.aborted)
+          {
+            oprot.writeI64(_iter424);
+          }
+          oprot.writeSetEnd();
+        }
+        oprot.writeFieldEnd();
+      }
+      if (struct.nosuch != null) {
+        oprot.writeFieldBegin(NOSUCH_FIELD_DESC);
+        {
+          oprot.writeSetBegin(new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, struct.nosuch.size()));
+          for (long _iter425 : struct.nosuch)
+          {
+            oprot.writeI64(_iter425);
+          }
+          oprot.writeSetEnd();
+        }
+        oprot.writeFieldEnd();
+      }
+      oprot.writeFieldStop();
+      oprot.writeStructEnd();
+    }
+
+  }
+
+  private static class HeartbeatTxnRangeResponseTupleSchemeFactory implements SchemeFactory {
+    public HeartbeatTxnRangeResponseTupleScheme getScheme() {
+      return new HeartbeatTxnRangeResponseTupleScheme();
+    }
+  }
+
+  private static class HeartbeatTxnRangeResponseTupleScheme extends TupleScheme<HeartbeatTxnRangeResponse> {
+
+    @Override
+    public void write(org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeResponse struct) throws org.apache.thrift.TException {
+      TTupleProtocol oprot = (TTupleProtocol) prot;
+      {
+        oprot.writeI32(struct.aborted.size());
+        for (long _iter426 : struct.aborted)
+        {
+          oprot.writeI64(_iter426);
+        }
+      }
+      {
+        oprot.writeI32(struct.nosuch.size());
+        for (long _iter427 : struct.nosuch)
+        {
+          oprot.writeI64(_iter427);
+        }
+      }
+    }
+
+    @Override
+    public void read(org.apache.thrift.protocol.TProtocol prot, HeartbeatTxnRangeResponse struct) throws org.apache.thrift.TException {
+      TTupleProtocol iprot = (TTupleProtocol) prot;
+      {
+        org.apache.thrift.protocol.TSet _set428 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, iprot.readI32());
+        struct.aborted = new HashSet<Long>(2*_set428.size);
+        for (int _i429 = 0; _i429 < _set428.size; ++_i429)
+        {
+          long _elem430; // required
+          _elem430 = iprot.readI64();
+          struct.aborted.add(_elem430);
+        }
+      }
+      struct.setAbortedIsSet(true);
+      {
+        org.apache.thrift.protocol.TSet _set431 = new org.apache.thrift.protocol.TSet(org.apache.thrift.protocol.TType.I64, iprot.readI32());
+        struct.nosuch = new HashSet<Long>(2*_set431.size);
+        for (int _i432 = 0; _i432 < _set431.size; ++_i432)
+        {
+          long _elem433; // required
+          _elem433 = iprot.readI64();
+          struct.nosuch.add(_elem433);
+        }
+      }
+      struct.setNosuchIsSet(true);
+    }
+  }
+
+}
+

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/HiveObjectRef.java Sun Mar 30 18:40:45 2014
@@ -710,7 +710,7 @@ public class HiveObjectRef implements or
                 struct.partValues = new ArrayList<String>(_list8.size);
                 for (int _i9 = 0; _i9 < _list8.size; ++_i9)
                 {
-                  String _elem10; // optional
+                  String _elem10; // required
                   _elem10 = iprot.readString();
                   struct.partValues.add(_elem10);
                 }
@@ -853,7 +853,7 @@ public class HiveObjectRef implements or
           struct.partValues = new ArrayList<String>(_list13.size);
           for (int _i14 = 0; _i14 < _list13.size; ++_i14)
           {
-            String _elem15; // optional
+            String _elem15; // required
             _elem15 = iprot.readString();
             struct.partValues.add(_elem15);
           }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/LockRequest.java Sun Mar 30 18:40:45 2014
@@ -605,7 +605,7 @@ public class LockRequest implements org.
                 struct.component = new ArrayList<LockComponent>(_list402.size);
                 for (int _i403 = 0; _i403 < _list402.size; ++_i403)
                 {
-                  LockComponent _elem404; // optional
+                  LockComponent _elem404; // required
                   _elem404 = new LockComponent();
                   _elem404.read(iprot);
                   struct.component.add(_elem404);
@@ -725,7 +725,7 @@ public class LockRequest implements org.
         struct.component = new ArrayList<LockComponent>(_list407.size);
         for (int _i408 = 0; _i408 < _list407.size; ++_i408)
         {
-          LockComponent _elem409; // optional
+          LockComponent _elem409; // required
           _elem409 = new LockComponent();
           _elem409.read(iprot);
           struct.component.add(_elem409);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/OpenTxnsResponse.java Sun Mar 30 18:40:45 2014
@@ -354,7 +354,7 @@ public class OpenTxnsResponse implements
                 struct.txn_ids = new ArrayList<Long>(_list394.size);
                 for (int _i395 = 0; _i395 < _list394.size; ++_i395)
                 {
-                  long _elem396; // optional
+                  long _elem396; // required
                   _elem396 = iprot.readI64();
                   struct.txn_ids.add(_elem396);
                 }
@@ -424,7 +424,7 @@ public class OpenTxnsResponse implements
         struct.txn_ids = new ArrayList<Long>(_list399.size);
         for (int _i400 = 0; _i400 < _list399.size; ++_i400)
         {
-          long _elem401; // optional
+          long _elem401; // required
           _elem401 = iprot.readI64();
           struct.txn_ids.add(_elem401);
         }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/Partition.java Sun Mar 30 18:40:45 2014
@@ -945,7 +945,7 @@ public class Partition implements org.ap
                 struct.values = new ArrayList<String>(_list208.size);
                 for (int _i209 = 0; _i209 < _list208.size; ++_i209)
                 {
-                  String _elem210; // optional
+                  String _elem210; // required
                   _elem210 = iprot.readString();
                   struct.values.add(_elem210);
                 }
@@ -1184,7 +1184,7 @@ public class Partition implements org.ap
           struct.values = new ArrayList<String>(_list219.size);
           for (int _i220 = 0; _i220 < _list219.size; ++_i220)
           {
-            String _elem221; // optional
+            String _elem221; // required
             _elem221 = iprot.readString();
             struct.values.add(_elem221);
           }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsByExprResult.java Sun Mar 30 18:40:45 2014
@@ -439,7 +439,7 @@ public class PartitionsByExprResult impl
                 struct.partitions = new ArrayList<Partition>(_list272.size);
                 for (int _i273 = 0; _i273 < _list272.size; ++_i273)
                 {
-                  Partition _elem274; // optional
+                  Partition _elem274; // required
                   _elem274 = new Partition();
                   _elem274.read(iprot);
                   struct.partitions.add(_elem274);
@@ -522,7 +522,7 @@ public class PartitionsByExprResult impl
         struct.partitions = new ArrayList<Partition>(_list277.size);
         for (int _i278 = 0; _i278 < _list277.size; ++_i278)
         {
-          Partition _elem279; // optional
+          Partition _elem279; // required
           _elem279 = new Partition();
           _elem279.read(iprot);
           struct.partitions.add(_elem279);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsRequest.java Sun Mar 30 18:40:45 2014
@@ -645,7 +645,7 @@ public class PartitionsStatsRequest impl
                 struct.colNames = new ArrayList<String>(_list314.size);
                 for (int _i315 = 0; _i315 < _list314.size; ++_i315)
                 {
-                  String _elem316; // optional
+                  String _elem316; // required
                   _elem316 = iprot.readString();
                   struct.colNames.add(_elem316);
                 }
@@ -663,7 +663,7 @@ public class PartitionsStatsRequest impl
                 struct.partNames = new ArrayList<String>(_list317.size);
                 for (int _i318 = 0; _i318 < _list317.size; ++_i318)
                 {
-                  String _elem319; // optional
+                  String _elem319; // required
                   _elem319 = iprot.readString();
                   struct.partNames.add(_elem319);
                 }
@@ -768,7 +768,7 @@ public class PartitionsStatsRequest impl
         struct.colNames = new ArrayList<String>(_list324.size);
         for (int _i325 = 0; _i325 < _list324.size; ++_i325)
         {
-          String _elem326; // optional
+          String _elem326; // required
           _elem326 = iprot.readString();
           struct.colNames.add(_elem326);
         }
@@ -779,7 +779,7 @@ public class PartitionsStatsRequest impl
         struct.partNames = new ArrayList<String>(_list327.size);
         for (int _i328 = 0; _i328 < _list327.size; ++_i328)
         {
-          String _elem329; // optional
+          String _elem329; // required
           _elem329 = iprot.readString();
           struct.partNames.add(_elem329);
         }

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PartitionsStatsResult.java Sun Mar 30 18:40:45 2014
@@ -371,7 +371,7 @@ public class PartitionsStatsResult imple
                     _val291 = new ArrayList<ColumnStatisticsObj>(_list292.size);
                     for (int _i293 = 0; _i293 < _list292.size; ++_i293)
                     {
-                      ColumnStatisticsObj _elem294; // optional
+                      ColumnStatisticsObj _elem294; // required
                       _elem294 = new ColumnStatisticsObj();
                       _elem294.read(iprot);
                       _val291.add(_elem294);
@@ -469,7 +469,7 @@ public class PartitionsStatsResult imple
             _val302 = new ArrayList<ColumnStatisticsObj>(_list303.size);
             for (int _i304 = 0; _i304 < _list303.size; ++_i304)
             {
-              ColumnStatisticsObj _elem305; // optional
+              ColumnStatisticsObj _elem305; // required
               _elem305 = new ColumnStatisticsObj();
               _elem305.read(iprot);
               _val302.add(_elem305);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrincipalPrivilegeSet.java Sun Mar 30 18:40:45 2014
@@ -587,7 +587,7 @@ public class PrincipalPrivilegeSet imple
                     _val27 = new ArrayList<PrivilegeGrantInfo>(_list28.size);
                     for (int _i29 = 0; _i29 < _list28.size; ++_i29)
                     {
-                      PrivilegeGrantInfo _elem30; // optional
+                      PrivilegeGrantInfo _elem30; // required
                       _elem30 = new PrivilegeGrantInfo();
                       _elem30.read(iprot);
                       _val27.add(_elem30);
@@ -618,7 +618,7 @@ public class PrincipalPrivilegeSet imple
                     _val34 = new ArrayList<PrivilegeGrantInfo>(_list35.size);
                     for (int _i36 = 0; _i36 < _list35.size; ++_i36)
                     {
-                      PrivilegeGrantInfo _elem37; // optional
+                      PrivilegeGrantInfo _elem37; // required
                       _elem37 = new PrivilegeGrantInfo();
                       _elem37.read(iprot);
                       _val34.add(_elem37);
@@ -649,7 +649,7 @@ public class PrincipalPrivilegeSet imple
                     _val41 = new ArrayList<PrivilegeGrantInfo>(_list42.size);
                     for (int _i43 = 0; _i43 < _list42.size; ++_i43)
                     {
-                      PrivilegeGrantInfo _elem44; // optional
+                      PrivilegeGrantInfo _elem44; // required
                       _elem44 = new PrivilegeGrantInfo();
                       _elem44.read(iprot);
                       _val41.add(_elem44);
@@ -834,7 +834,7 @@ public class PrincipalPrivilegeSet imple
               _val60 = new ArrayList<PrivilegeGrantInfo>(_list61.size);
               for (int _i62 = 0; _i62 < _list61.size; ++_i62)
               {
-                PrivilegeGrantInfo _elem63; // optional
+                PrivilegeGrantInfo _elem63; // required
                 _elem63 = new PrivilegeGrantInfo();
                 _elem63.read(iprot);
                 _val60.add(_elem63);
@@ -859,7 +859,7 @@ public class PrincipalPrivilegeSet imple
               _val67 = new ArrayList<PrivilegeGrantInfo>(_list68.size);
               for (int _i69 = 0; _i69 < _list68.size; ++_i69)
               {
-                PrivilegeGrantInfo _elem70; // optional
+                PrivilegeGrantInfo _elem70; // required
                 _elem70 = new PrivilegeGrantInfo();
                 _elem70.read(iprot);
                 _val67.add(_elem70);
@@ -884,7 +884,7 @@ public class PrincipalPrivilegeSet imple
               _val74 = new ArrayList<PrivilegeGrantInfo>(_list75.size);
               for (int _i76 = 0; _i76 < _list75.size; ++_i76)
               {
-                PrivilegeGrantInfo _elem77; // optional
+                PrivilegeGrantInfo _elem77; // required
                 _elem77 = new PrivilegeGrantInfo();
                 _elem77.read(iprot);
                 _val74.add(_elem77);

Modified: hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java
URL: http://svn.apache.org/viewvc/hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java?rev=1583186&r1=1583185&r2=1583186&view=diff
==============================================================================
--- hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java (original)
+++ hive/branches/branch-0.13/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/PrivilegeBag.java Sun Mar 30 18:40:45 2014
@@ -350,7 +350,7 @@ public class PrivilegeBag implements org
                 struct.privileges = new ArrayList<HiveObjectPrivilege>(_list16.size);
                 for (int _i17 = 0; _i17 < _list16.size; ++_i17)
                 {
-                  HiveObjectPrivilege _elem18; // optional
+                  HiveObjectPrivilege _elem18; // required
                   _elem18 = new HiveObjectPrivilege();
                   _elem18.read(iprot);
                   struct.privileges.add(_elem18);
@@ -430,7 +430,7 @@ public class PrivilegeBag implements org
           struct.privileges = new ArrayList<HiveObjectPrivilege>(_list21.size);
           for (int _i22 = 0; _i22 < _list21.size; ++_i22)
           {
-            HiveObjectPrivilege _elem23; // optional
+            HiveObjectPrivilege _elem23; // required
             _elem23 = new HiveObjectPrivilege();
             _elem23.read(iprot);
             struct.privileges.add(_elem23);