You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by we...@apache.org on 2016/05/10 18:05:57 UTC

[4/8] hive git commit: HIVE-12634 : Add command to kill an ACID transacton (Wei Zheng, reviewed by Eugene Koifman)

http://git-wip-us.apache.org/repos/asf/hive/blob/aecb0c02/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
----------------------------------------------------------------------
diff --git a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
index bc417ef..e836154 100644
--- a/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
+++ b/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java
@@ -266,6 +266,8 @@ public class ThriftHiveMetastore {
 
     public void abort_txn(AbortTxnRequest rqst) throws NoSuchTxnException, org.apache.thrift.TException;
 
+    public void abort_txns(AbortTxnsRequest rqst) throws NoSuchTxnException, org.apache.thrift.TException;
+
     public void commit_txn(CommitTxnRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException;
 
     public LockResponse lock(LockRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException;
@@ -520,6 +522,8 @@ public class ThriftHiveMetastore {
 
     public void abort_txn(AbortTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
+    public void abort_txns(AbortTxnsRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
+
     public void commit_txn(CommitTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
 
     public void lock(LockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException;
@@ -3937,6 +3941,29 @@ public class ThriftHiveMetastore {
       return;
     }
 
+    public void abort_txns(AbortTxnsRequest rqst) throws NoSuchTxnException, org.apache.thrift.TException
+    {
+      send_abort_txns(rqst);
+      recv_abort_txns();
+    }
+
+    public void send_abort_txns(AbortTxnsRequest rqst) throws org.apache.thrift.TException
+    {
+      abort_txns_args args = new abort_txns_args();
+      args.setRqst(rqst);
+      sendBase("abort_txns", args);
+    }
+
+    public void recv_abort_txns() throws NoSuchTxnException, org.apache.thrift.TException
+    {
+      abort_txns_result result = new abort_txns_result();
+      receiveBase(result, "abort_txns");
+      if (result.o1 != null) {
+        throw result.o1;
+      }
+      return;
+    }
+
     public void commit_txn(CommitTxnRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException
     {
       send_commit_txn(rqst);
@@ -8326,6 +8353,38 @@ public class ThriftHiveMetastore {
       }
     }
 
+    public void abort_txns(AbortTxnsRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
+      checkReady();
+      abort_txns_call method_call = new abort_txns_call(rqst, resultHandler, this, ___protocolFactory, ___transport);
+      this.___currentMethod = method_call;
+      ___manager.call(method_call);
+    }
+
+    public static class abort_txns_call extends org.apache.thrift.async.TAsyncMethodCall {
+      private AbortTxnsRequest rqst;
+      public abort_txns_call(AbortTxnsRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException {
+        super(client, protocolFactory, transport, resultHandler, false);
+        this.rqst = rqst;
+      }
+
+      public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException {
+        prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("abort_txns", org.apache.thrift.protocol.TMessageType.CALL, 0));
+        abort_txns_args args = new abort_txns_args();
+        args.setRqst(rqst);
+        args.write(prot);
+        prot.writeMessageEnd();
+      }
+
+      public void getResult() throws NoSuchTxnException, org.apache.thrift.TException {
+        if (getState() != org.apache.thrift.async.TAsyncMethodCall.State.RESPONSE_READ) {
+          throw new IllegalStateException("Method call not finished!");
+        }
+        org.apache.thrift.transport.TMemoryInputTransport memoryTransport = new org.apache.thrift.transport.TMemoryInputTransport(getFrameBuffer().array());
+        org.apache.thrift.protocol.TProtocol prot = client.getProtocolFactory().getProtocol(memoryTransport);
+        (new Client(prot)).recv_abort_txns();
+      }
+    }
+
     public void commit_txn(CommitTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException {
       checkReady();
       commit_txn_call method_call = new commit_txn_call(rqst, resultHandler, this, ___protocolFactory, ___transport);
@@ -8864,6 +8923,7 @@ public class ThriftHiveMetastore {
       processMap.put("get_open_txns_info", new get_open_txns_info());
       processMap.put("open_txns", new open_txns());
       processMap.put("abort_txn", new abort_txn());
+      processMap.put("abort_txns", new abort_txns());
       processMap.put("commit_txn", new commit_txn());
       processMap.put("lock", new lock());
       processMap.put("check_lock", new check_lock());
@@ -11831,6 +11891,30 @@ public class ThriftHiveMetastore {
       }
     }
 
+    public static class abort_txns<I extends Iface> extends org.apache.thrift.ProcessFunction<I, abort_txns_args> {
+      public abort_txns() {
+        super("abort_txns");
+      }
+
+      public abort_txns_args getEmptyArgsInstance() {
+        return new abort_txns_args();
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public abort_txns_result getResult(I iface, abort_txns_args args) throws org.apache.thrift.TException {
+        abort_txns_result result = new abort_txns_result();
+        try {
+          iface.abort_txns(args.rqst);
+        } catch (NoSuchTxnException o1) {
+          result.o1 = o1;
+        }
+        return result;
+      }
+    }
+
     public static class commit_txn<I extends Iface> extends org.apache.thrift.ProcessFunction<I, commit_txn_args> {
       public commit_txn() {
         super("commit_txn");
@@ -12256,6 +12340,7 @@ public class ThriftHiveMetastore {
       processMap.put("get_open_txns_info", new get_open_txns_info());
       processMap.put("open_txns", new open_txns());
       processMap.put("abort_txn", new abort_txn());
+      processMap.put("abort_txns", new abort_txns());
       processMap.put("commit_txn", new commit_txn());
       processMap.put("lock", new lock());
       processMap.put("check_lock", new check_lock());
@@ -19269,6 +19354,62 @@ public class ThriftHiveMetastore {
       }
     }
 
+    public static class abort_txns<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, abort_txns_args, Void> {
+      public abort_txns() {
+        super("abort_txns");
+      }
+
+      public abort_txns_args getEmptyArgsInstance() {
+        return new abort_txns_args();
+      }
+
+      public AsyncMethodCallback<Void> getResultHandler(final AsyncFrameBuffer fb, final int seqid) {
+        final org.apache.thrift.AsyncProcessFunction fcall = this;
+        return new AsyncMethodCallback<Void>() { 
+          public void onComplete(Void o) {
+            abort_txns_result result = new abort_txns_result();
+            try {
+              fcall.sendResponse(fb,result, org.apache.thrift.protocol.TMessageType.REPLY,seqid);
+              return;
+            } catch (Exception e) {
+              LOGGER.error("Exception writing to internal frame buffer", e);
+            }
+            fb.close();
+          }
+          public void onError(Exception e) {
+            byte msgType = org.apache.thrift.protocol.TMessageType.REPLY;
+            org.apache.thrift.TBase msg;
+            abort_txns_result result = new abort_txns_result();
+            if (e instanceof NoSuchTxnException) {
+                        result.o1 = (NoSuchTxnException) e;
+                        result.setO1IsSet(true);
+                        msg = result;
+            }
+             else 
+            {
+              msgType = org.apache.thrift.protocol.TMessageType.EXCEPTION;
+              msg = (org.apache.thrift.TBase)new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.INTERNAL_ERROR, e.getMessage());
+            }
+            try {
+              fcall.sendResponse(fb,msg,msgType,seqid);
+              return;
+            } catch (Exception ex) {
+              LOGGER.error("Exception writing to internal frame buffer", ex);
+            }
+            fb.close();
+          }
+        };
+      }
+
+      protected boolean isOneway() {
+        return false;
+      }
+
+      public void start(I iface, abort_txns_args args, org.apache.thrift.async.AsyncMethodCallback<Void> resultHandler) throws TException {
+        iface.abort_txns(args.rqst,resultHandler);
+      }
+    }
+
     public static class commit_txn<I extends AsyncIface> extends org.apache.thrift.AsyncProcessFunction<I, commit_txn_args, Void> {
       public commit_txn() {
         super("commit_txn");
@@ -25398,13 +25539,13 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list532 = iprot.readListBegin();
-                  struct.success = new ArrayList<String>(_list532.size);
-                  String _elem533;
-                  for (int _i534 = 0; _i534 < _list532.size; ++_i534)
+                  org.apache.thrift.protocol.TList _list540 = iprot.readListBegin();
+                  struct.success = new ArrayList<String>(_list540.size);
+                  String _elem541;
+                  for (int _i542 = 0; _i542 < _list540.size; ++_i542)
                   {
-                    _elem533 = iprot.readString();
-                    struct.success.add(_elem533);
+                    _elem541 = iprot.readString();
+                    struct.success.add(_elem541);
                   }
                   iprot.readListEnd();
                 }
@@ -25439,9 +25580,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (String _iter535 : struct.success)
+            for (String _iter543 : struct.success)
             {
-              oprot.writeString(_iter535);
+              oprot.writeString(_iter543);
             }
             oprot.writeListEnd();
           }
@@ -25480,9 +25621,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (String _iter536 : struct.success)
+            for (String _iter544 : struct.success)
             {
-              oprot.writeString(_iter536);
+              oprot.writeString(_iter544);
             }
           }
         }
@@ -25497,13 +25638,13 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list537 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new ArrayList<String>(_list537.size);
-            String _elem538;
-            for (int _i539 = 0; _i539 < _list537.size; ++_i539)
+            org.apache.thrift.protocol.TList _list545 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new ArrayList<String>(_list545.size);
+            String _elem546;
+            for (int _i547 = 0; _i547 < _list545.size; ++_i547)
             {
-              _elem538 = iprot.readString();
-              struct.success.add(_elem538);
+              _elem546 = iprot.readString();
+              struct.success.add(_elem546);
             }
           }
           struct.setSuccessIsSet(true);
@@ -26157,13 +26298,13 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list540 = iprot.readListBegin();
-                  struct.success = new ArrayList<String>(_list540.size);
-                  String _elem541;
-                  for (int _i542 = 0; _i542 < _list540.size; ++_i542)
+                  org.apache.thrift.protocol.TList _list548 = iprot.readListBegin();
+                  struct.success = new ArrayList<String>(_list548.size);
+                  String _elem549;
+                  for (int _i550 = 0; _i550 < _list548.size; ++_i550)
                   {
-                    _elem541 = iprot.readString();
-                    struct.success.add(_elem541);
+                    _elem549 = iprot.readString();
+                    struct.success.add(_elem549);
                   }
                   iprot.readListEnd();
                 }
@@ -26198,9 +26339,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (String _iter543 : struct.success)
+            for (String _iter551 : struct.success)
             {
-              oprot.writeString(_iter543);
+              oprot.writeString(_iter551);
             }
             oprot.writeListEnd();
           }
@@ -26239,9 +26380,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (String _iter544 : struct.success)
+            for (String _iter552 : struct.success)
             {
-              oprot.writeString(_iter544);
+              oprot.writeString(_iter552);
             }
           }
         }
@@ -26256,13 +26397,13 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list545 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new ArrayList<String>(_list545.size);
-            String _elem546;
-            for (int _i547 = 0; _i547 < _list545.size; ++_i547)
+            org.apache.thrift.protocol.TList _list553 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new ArrayList<String>(_list553.size);
+            String _elem554;
+            for (int _i555 = 0; _i555 < _list553.size; ++_i555)
             {
-              _elem546 = iprot.readString();
-              struct.success.add(_elem546);
+              _elem554 = iprot.readString();
+              struct.success.add(_elem554);
             }
           }
           struct.setSuccessIsSet(true);
@@ -30869,16 +31010,16 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map548 = iprot.readMapBegin();
-                  struct.success = new HashMap<String,Type>(2*_map548.size);
-                  String _key549;
-                  Type _val550;
-                  for (int _i551 = 0; _i551 < _map548.size; ++_i551)
+                  org.apache.thrift.protocol.TMap _map556 = iprot.readMapBegin();
+                  struct.success = new HashMap<String,Type>(2*_map556.size);
+                  String _key557;
+                  Type _val558;
+                  for (int _i559 = 0; _i559 < _map556.size; ++_i559)
                   {
-                    _key549 = iprot.readString();
-                    _val550 = new Type();
-                    _val550.read(iprot);
-                    struct.success.put(_key549, _val550);
+                    _key557 = iprot.readString();
+                    _val558 = new Type();
+                    _val558.read(iprot);
+                    struct.success.put(_key557, _val558);
                   }
                   iprot.readMapEnd();
                 }
@@ -30913,10 +31054,10 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (Map.Entry<String, Type> _iter552 : struct.success.entrySet())
+            for (Map.Entry<String, Type> _iter560 : struct.success.entrySet())
             {
-              oprot.writeString(_iter552.getKey());
-              _iter552.getValue().write(oprot);
+              oprot.writeString(_iter560.getKey());
+              _iter560.getValue().write(oprot);
             }
             oprot.writeMapEnd();
           }
@@ -30955,10 +31096,10 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (Map.Entry<String, Type> _iter553 : struct.success.entrySet())
+            for (Map.Entry<String, Type> _iter561 : struct.success.entrySet())
             {
-              oprot.writeString(_iter553.getKey());
-              _iter553.getValue().write(oprot);
+              oprot.writeString(_iter561.getKey());
+              _iter561.getValue().write(oprot);
             }
           }
         }
@@ -30973,16 +31114,16 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map554 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new HashMap<String,Type>(2*_map554.size);
-            String _key555;
-            Type _val556;
-            for (int _i557 = 0; _i557 < _map554.size; ++_i557)
+            org.apache.thrift.protocol.TMap _map562 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new HashMap<String,Type>(2*_map562.size);
+            String _key563;
+            Type _val564;
+            for (int _i565 = 0; _i565 < _map562.size; ++_i565)
             {
-              _key555 = iprot.readString();
-              _val556 = new Type();
-              _val556.read(iprot);
-              struct.success.put(_key555, _val556);
+              _key563 = iprot.readString();
+              _val564 = new Type();
+              _val564.read(iprot);
+              struct.success.put(_key563, _val564);
             }
           }
           struct.setSuccessIsSet(true);
@@ -32017,14 +32158,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list558 = iprot.readListBegin();
-                  struct.success = new ArrayList<FieldSchema>(_list558.size);
-                  FieldSchema _elem559;
-                  for (int _i560 = 0; _i560 < _list558.size; ++_i560)
+                  org.apache.thrift.protocol.TList _list566 = iprot.readListBegin();
+                  struct.success = new ArrayList<FieldSchema>(_list566.size);
+                  FieldSchema _elem567;
+                  for (int _i568 = 0; _i568 < _list566.size; ++_i568)
                   {
-                    _elem559 = new FieldSchema();
-                    _elem559.read(iprot);
-                    struct.success.add(_elem559);
+                    _elem567 = new FieldSchema();
+                    _elem567.read(iprot);
+                    struct.success.add(_elem567);
                   }
                   iprot.readListEnd();
                 }
@@ -32077,9 +32218,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (FieldSchema _iter561 : struct.success)
+            for (FieldSchema _iter569 : struct.success)
             {
-              _iter561.write(oprot);
+              _iter569.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -32134,9 +32275,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (FieldSchema _iter562 : struct.success)
+            for (FieldSchema _iter570 : struct.success)
             {
-              _iter562.write(oprot);
+              _iter570.write(oprot);
             }
           }
         }
@@ -32157,14 +32298,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list563 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<FieldSchema>(_list563.size);
-            FieldSchema _elem564;
-            for (int _i565 = 0; _i565 < _list563.size; ++_i565)
+            org.apache.thrift.protocol.TList _list571 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<FieldSchema>(_list571.size);
+            FieldSchema _elem572;
+            for (int _i573 = 0; _i573 < _list571.size; ++_i573)
             {
-              _elem564 = new FieldSchema();
-              _elem564.read(iprot);
-              struct.success.add(_elem564);
+              _elem572 = new FieldSchema();
+              _elem572.read(iprot);
+              struct.success.add(_elem572);
             }
           }
           struct.setSuccessIsSet(true);
@@ -33318,14 +33459,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list566 = iprot.readListBegin();
-                  struct.success = new ArrayList<FieldSchema>(_list566.size);
-                  FieldSchema _elem567;
-                  for (int _i568 = 0; _i568 < _list566.size; ++_i568)
+                  org.apache.thrift.protocol.TList _list574 = iprot.readListBegin();
+                  struct.success = new ArrayList<FieldSchema>(_list574.size);
+                  FieldSchema _elem575;
+                  for (int _i576 = 0; _i576 < _list574.size; ++_i576)
                   {
-                    _elem567 = new FieldSchema();
-                    _elem567.read(iprot);
-                    struct.success.add(_elem567);
+                    _elem575 = new FieldSchema();
+                    _elem575.read(iprot);
+                    struct.success.add(_elem575);
                   }
                   iprot.readListEnd();
                 }
@@ -33378,9 +33519,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (FieldSchema _iter569 : struct.success)
+            for (FieldSchema _iter577 : struct.success)
             {
-              _iter569.write(oprot);
+              _iter577.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -33435,9 +33576,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (FieldSchema _iter570 : struct.success)
+            for (FieldSchema _iter578 : struct.success)
             {
-              _iter570.write(oprot);
+              _iter578.write(oprot);
             }
           }
         }
@@ -33458,14 +33599,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list571 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<FieldSchema>(_list571.size);
-            FieldSchema _elem572;
-            for (int _i573 = 0; _i573 < _list571.size; ++_i573)
+            org.apache.thrift.protocol.TList _list579 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<FieldSchema>(_list579.size);
+            FieldSchema _elem580;
+            for (int _i581 = 0; _i581 < _list579.size; ++_i581)
             {
-              _elem572 = new FieldSchema();
-              _elem572.read(iprot);
-              struct.success.add(_elem572);
+              _elem580 = new FieldSchema();
+              _elem580.read(iprot);
+              struct.success.add(_elem580);
             }
           }
           struct.setSuccessIsSet(true);
@@ -34510,14 +34651,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list574 = iprot.readListBegin();
-                  struct.success = new ArrayList<FieldSchema>(_list574.size);
-                  FieldSchema _elem575;
-                  for (int _i576 = 0; _i576 < _list574.size; ++_i576)
+                  org.apache.thrift.protocol.TList _list582 = iprot.readListBegin();
+                  struct.success = new ArrayList<FieldSchema>(_list582.size);
+                  FieldSchema _elem583;
+                  for (int _i584 = 0; _i584 < _list582.size; ++_i584)
                   {
-                    _elem575 = new FieldSchema();
-                    _elem575.read(iprot);
-                    struct.success.add(_elem575);
+                    _elem583 = new FieldSchema();
+                    _elem583.read(iprot);
+                    struct.success.add(_elem583);
                   }
                   iprot.readListEnd();
                 }
@@ -34570,9 +34711,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (FieldSchema _iter577 : struct.success)
+            for (FieldSchema _iter585 : struct.success)
             {
-              _iter577.write(oprot);
+              _iter585.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -34627,9 +34768,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (FieldSchema _iter578 : struct.success)
+            for (FieldSchema _iter586 : struct.success)
             {
-              _iter578.write(oprot);
+              _iter586.write(oprot);
             }
           }
         }
@@ -34650,14 +34791,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list579 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<FieldSchema>(_list579.size);
-            FieldSchema _elem580;
-            for (int _i581 = 0; _i581 < _list579.size; ++_i581)
+            org.apache.thrift.protocol.TList _list587 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<FieldSchema>(_list587.size);
+            FieldSchema _elem588;
+            for (int _i589 = 0; _i589 < _list587.size; ++_i589)
             {
-              _elem580 = new FieldSchema();
-              _elem580.read(iprot);
-              struct.success.add(_elem580);
+              _elem588 = new FieldSchema();
+              _elem588.read(iprot);
+              struct.success.add(_elem588);
             }
           }
           struct.setSuccessIsSet(true);
@@ -35811,14 +35952,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list582 = iprot.readListBegin();
-                  struct.success = new ArrayList<FieldSchema>(_list582.size);
-                  FieldSchema _elem583;
-                  for (int _i584 = 0; _i584 < _list582.size; ++_i584)
+                  org.apache.thrift.protocol.TList _list590 = iprot.readListBegin();
+                  struct.success = new ArrayList<FieldSchema>(_list590.size);
+                  FieldSchema _elem591;
+                  for (int _i592 = 0; _i592 < _list590.size; ++_i592)
                   {
-                    _elem583 = new FieldSchema();
-                    _elem583.read(iprot);
-                    struct.success.add(_elem583);
+                    _elem591 = new FieldSchema();
+                    _elem591.read(iprot);
+                    struct.success.add(_elem591);
                   }
                   iprot.readListEnd();
                 }
@@ -35871,9 +36012,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (FieldSchema _iter585 : struct.success)
+            for (FieldSchema _iter593 : struct.success)
             {
-              _iter585.write(oprot);
+              _iter593.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -35928,9 +36069,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (FieldSchema _iter586 : struct.success)
+            for (FieldSchema _iter594 : struct.success)
             {
-              _iter586.write(oprot);
+              _iter594.write(oprot);
             }
           }
         }
@@ -35951,14 +36092,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list587 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<FieldSchema>(_list587.size);
-            FieldSchema _elem588;
-            for (int _i589 = 0; _i589 < _list587.size; ++_i589)
+            org.apache.thrift.protocol.TList _list595 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<FieldSchema>(_list595.size);
+            FieldSchema _elem596;
+            for (int _i597 = 0; _i597 < _list595.size; ++_i597)
             {
-              _elem588 = new FieldSchema();
-              _elem588.read(iprot);
-              struct.success.add(_elem588);
+              _elem596 = new FieldSchema();
+              _elem596.read(iprot);
+              struct.success.add(_elem596);
             }
           }
           struct.setSuccessIsSet(true);
@@ -41198,13 +41339,13 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list590 = iprot.readListBegin();
-                  struct.success = new ArrayList<String>(_list590.size);
-                  String _elem591;
-                  for (int _i592 = 0; _i592 < _list590.size; ++_i592)
+                  org.apache.thrift.protocol.TList _list598 = iprot.readListBegin();
+                  struct.success = new ArrayList<String>(_list598.size);
+                  String _elem599;
+                  for (int _i600 = 0; _i600 < _list598.size; ++_i600)
                   {
-                    _elem591 = iprot.readString();
-                    struct.success.add(_elem591);
+                    _elem599 = iprot.readString();
+                    struct.success.add(_elem599);
                   }
                   iprot.readListEnd();
                 }
@@ -41239,9 +41380,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (String _iter593 : struct.success)
+            for (String _iter601 : struct.success)
             {
-              oprot.writeString(_iter593);
+              oprot.writeString(_iter601);
             }
             oprot.writeListEnd();
           }
@@ -41280,9 +41421,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (String _iter594 : struct.success)
+            for (String _iter602 : struct.success)
             {
-              oprot.writeString(_iter594);
+              oprot.writeString(_iter602);
             }
           }
         }
@@ -41297,13 +41438,13 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list595 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new ArrayList<String>(_list595.size);
-            String _elem596;
-            for (int _i597 = 0; _i597 < _list595.size; ++_i597)
+            org.apache.thrift.protocol.TList _list603 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new ArrayList<String>(_list603.size);
+            String _elem604;
+            for (int _i605 = 0; _i605 < _list603.size; ++_i605)
             {
-              _elem596 = iprot.readString();
-              struct.success.add(_elem596);
+              _elem604 = iprot.readString();
+              struct.success.add(_elem604);
             }
           }
           struct.setSuccessIsSet(true);
@@ -42069,13 +42210,13 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list598 = iprot.readListBegin();
-                  struct.success = new ArrayList<String>(_list598.size);
-                  String _elem599;
-                  for (int _i600 = 0; _i600 < _list598.size; ++_i600)
+                  org.apache.thrift.protocol.TList _list606 = iprot.readListBegin();
+                  struct.success = new ArrayList<String>(_list606.size);
+                  String _elem607;
+                  for (int _i608 = 0; _i608 < _list606.size; ++_i608)
                   {
-                    _elem599 = iprot.readString();
-                    struct.success.add(_elem599);
+                    _elem607 = iprot.readString();
+                    struct.success.add(_elem607);
                   }
                   iprot.readListEnd();
                 }
@@ -42110,9 +42251,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (String _iter601 : struct.success)
+            for (String _iter609 : struct.success)
             {
-              oprot.writeString(_iter601);
+              oprot.writeString(_iter609);
             }
             oprot.writeListEnd();
           }
@@ -42151,9 +42292,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (String _iter602 : struct.success)
+            for (String _iter610 : struct.success)
             {
-              oprot.writeString(_iter602);
+              oprot.writeString(_iter610);
             }
           }
         }
@@ -42168,13 +42309,13 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(2);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list603 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new ArrayList<String>(_list603.size);
-            String _elem604;
-            for (int _i605 = 0; _i605 < _list603.size; ++_i605)
+            org.apache.thrift.protocol.TList _list611 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new ArrayList<String>(_list611.size);
+            String _elem612;
+            for (int _i613 = 0; _i613 < _list611.size; ++_i613)
             {
-              _elem604 = iprot.readString();
-              struct.success.add(_elem604);
+              _elem612 = iprot.readString();
+              struct.success.add(_elem612);
             }
           }
           struct.setSuccessIsSet(true);
@@ -43627,13 +43768,13 @@ public class ThriftHiveMetastore {
             case 2: // TBL_NAMES
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list606 = iprot.readListBegin();
-                  struct.tbl_names = new ArrayList<String>(_list606.size);
-                  String _elem607;
-                  for (int _i608 = 0; _i608 < _list606.size; ++_i608)
+                  org.apache.thrift.protocol.TList _list614 = iprot.readListBegin();
+                  struct.tbl_names = new ArrayList<String>(_list614.size);
+                  String _elem615;
+                  for (int _i616 = 0; _i616 < _list614.size; ++_i616)
                   {
-                    _elem607 = iprot.readString();
-                    struct.tbl_names.add(_elem607);
+                    _elem615 = iprot.readString();
+                    struct.tbl_names.add(_elem615);
                   }
                   iprot.readListEnd();
                 }
@@ -43664,9 +43805,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(TBL_NAMES_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.tbl_names.size()));
-            for (String _iter609 : struct.tbl_names)
+            for (String _iter617 : struct.tbl_names)
             {
-              oprot.writeString(_iter609);
+              oprot.writeString(_iter617);
             }
             oprot.writeListEnd();
           }
@@ -43703,9 +43844,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetTbl_names()) {
           {
             oprot.writeI32(struct.tbl_names.size());
-            for (String _iter610 : struct.tbl_names)
+            for (String _iter618 : struct.tbl_names)
             {
-              oprot.writeString(_iter610);
+              oprot.writeString(_iter618);
             }
           }
         }
@@ -43721,13 +43862,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(1)) {
           {
-            org.apache.thrift.protocol.TList _list611 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.tbl_names = new ArrayList<String>(_list611.size);
-            String _elem612;
-            for (int _i613 = 0; _i613 < _list611.size; ++_i613)
+            org.apache.thrift.protocol.TList _list619 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.tbl_names = new ArrayList<String>(_list619.size);
+            String _elem620;
+            for (int _i621 = 0; _i621 < _list619.size; ++_i621)
             {
-              _elem612 = iprot.readString();
-              struct.tbl_names.add(_elem612);
+              _elem620 = iprot.readString();
+              struct.tbl_names.add(_elem620);
             }
           }
           struct.setTbl_namesIsSet(true);
@@ -44295,14 +44436,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list614 = iprot.readListBegin();
-                  struct.success = new ArrayList<Table>(_list614.size);
-                  Table _elem615;
-                  for (int _i616 = 0; _i616 < _list614.size; ++_i616)
+                  org.apache.thrift.protocol.TList _list622 = iprot.readListBegin();
+                  struct.success = new ArrayList<Table>(_list622.size);
+                  Table _elem623;
+                  for (int _i624 = 0; _i624 < _list622.size; ++_i624)
                   {
-                    _elem615 = new Table();
-                    _elem615.read(iprot);
-                    struct.success.add(_elem615);
+                    _elem623 = new Table();
+                    _elem623.read(iprot);
+                    struct.success.add(_elem623);
                   }
                   iprot.readListEnd();
                 }
@@ -44355,9 +44496,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (Table _iter617 : struct.success)
+            for (Table _iter625 : struct.success)
             {
-              _iter617.write(oprot);
+              _iter625.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -44412,9 +44553,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (Table _iter618 : struct.success)
+            for (Table _iter626 : struct.success)
             {
-              _iter618.write(oprot);
+              _iter626.write(oprot);
             }
           }
         }
@@ -44435,14 +44576,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list619 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<Table>(_list619.size);
-            Table _elem620;
-            for (int _i621 = 0; _i621 < _list619.size; ++_i621)
+            org.apache.thrift.protocol.TList _list627 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<Table>(_list627.size);
+            Table _elem628;
+            for (int _i629 = 0; _i629 < _list627.size; ++_i629)
             {
-              _elem620 = new Table();
-              _elem620.read(iprot);
-              struct.success.add(_elem620);
+              _elem628 = new Table();
+              _elem628.read(iprot);
+              struct.success.add(_elem628);
             }
           }
           struct.setSuccessIsSet(true);
@@ -45588,13 +45729,13 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list622 = iprot.readListBegin();
-                  struct.success = new ArrayList<String>(_list622.size);
-                  String _elem623;
-                  for (int _i624 = 0; _i624 < _list622.size; ++_i624)
+                  org.apache.thrift.protocol.TList _list630 = iprot.readListBegin();
+                  struct.success = new ArrayList<String>(_list630.size);
+                  String _elem631;
+                  for (int _i632 = 0; _i632 < _list630.size; ++_i632)
                   {
-                    _elem623 = iprot.readString();
-                    struct.success.add(_elem623);
+                    _elem631 = iprot.readString();
+                    struct.success.add(_elem631);
                   }
                   iprot.readListEnd();
                 }
@@ -45647,9 +45788,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.success.size()));
-            for (String _iter625 : struct.success)
+            for (String _iter633 : struct.success)
             {
-              oprot.writeString(_iter625);
+              oprot.writeString(_iter633);
             }
             oprot.writeListEnd();
           }
@@ -45704,9 +45845,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (String _iter626 : struct.success)
+            for (String _iter634 : struct.success)
             {
-              oprot.writeString(_iter626);
+              oprot.writeString(_iter634);
             }
           }
         }
@@ -45727,13 +45868,13 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(4);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list627 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.success = new ArrayList<String>(_list627.size);
-            String _elem628;
-            for (int _i629 = 0; _i629 < _list627.size; ++_i629)
+            org.apache.thrift.protocol.TList _list635 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.success = new ArrayList<String>(_list635.size);
+            String _elem636;
+            for (int _i637 = 0; _i637 < _list635.size; ++_i637)
             {
-              _elem628 = iprot.readString();
-              struct.success.add(_elem628);
+              _elem636 = iprot.readString();
+              struct.success.add(_elem636);
             }
           }
           struct.setSuccessIsSet(true);
@@ -51592,14 +51733,14 @@ public class ThriftHiveMetastore {
             case 1: // NEW_PARTS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list630 = iprot.readListBegin();
-                  struct.new_parts = new ArrayList<Partition>(_list630.size);
-                  Partition _elem631;
-                  for (int _i632 = 0; _i632 < _list630.size; ++_i632)
+                  org.apache.thrift.protocol.TList _list638 = iprot.readListBegin();
+                  struct.new_parts = new ArrayList<Partition>(_list638.size);
+                  Partition _elem639;
+                  for (int _i640 = 0; _i640 < _list638.size; ++_i640)
                   {
-                    _elem631 = new Partition();
-                    _elem631.read(iprot);
-                    struct.new_parts.add(_elem631);
+                    _elem639 = new Partition();
+                    _elem639.read(iprot);
+                    struct.new_parts.add(_elem639);
                   }
                   iprot.readListEnd();
                 }
@@ -51625,9 +51766,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(NEW_PARTS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.new_parts.size()));
-            for (Partition _iter633 : struct.new_parts)
+            for (Partition _iter641 : struct.new_parts)
             {
-              _iter633.write(oprot);
+              _iter641.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -51658,9 +51799,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetNew_parts()) {
           {
             oprot.writeI32(struct.new_parts.size());
-            for (Partition _iter634 : struct.new_parts)
+            for (Partition _iter642 : struct.new_parts)
             {
-              _iter634.write(oprot);
+              _iter642.write(oprot);
             }
           }
         }
@@ -51672,14 +51813,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list635 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.new_parts = new ArrayList<Partition>(_list635.size);
-            Partition _elem636;
-            for (int _i637 = 0; _i637 < _list635.size; ++_i637)
+            org.apache.thrift.protocol.TList _list643 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.new_parts = new ArrayList<Partition>(_list643.size);
+            Partition _elem644;
+            for (int _i645 = 0; _i645 < _list643.size; ++_i645)
             {
-              _elem636 = new Partition();
-              _elem636.read(iprot);
-              struct.new_parts.add(_elem636);
+              _elem644 = new Partition();
+              _elem644.read(iprot);
+              struct.new_parts.add(_elem644);
             }
           }
           struct.setNew_partsIsSet(true);
@@ -52680,14 +52821,14 @@ public class ThriftHiveMetastore {
             case 1: // NEW_PARTS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list638 = iprot.readListBegin();
-                  struct.new_parts = new ArrayList<PartitionSpec>(_list638.size);
-                  PartitionSpec _elem639;
-                  for (int _i640 = 0; _i640 < _list638.size; ++_i640)
+                  org.apache.thrift.protocol.TList _list646 = iprot.readListBegin();
+                  struct.new_parts = new ArrayList<PartitionSpec>(_list646.size);
+                  PartitionSpec _elem647;
+                  for (int _i648 = 0; _i648 < _list646.size; ++_i648)
                   {
-                    _elem639 = new PartitionSpec();
-                    _elem639.read(iprot);
-                    struct.new_parts.add(_elem639);
+                    _elem647 = new PartitionSpec();
+                    _elem647.read(iprot);
+                    struct.new_parts.add(_elem647);
                   }
                   iprot.readListEnd();
                 }
@@ -52713,9 +52854,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(NEW_PARTS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.new_parts.size()));
-            for (PartitionSpec _iter641 : struct.new_parts)
+            for (PartitionSpec _iter649 : struct.new_parts)
             {
-              _iter641.write(oprot);
+              _iter649.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -52746,9 +52887,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetNew_parts()) {
           {
             oprot.writeI32(struct.new_parts.size());
-            for (PartitionSpec _iter642 : struct.new_parts)
+            for (PartitionSpec _iter650 : struct.new_parts)
             {
-              _iter642.write(oprot);
+              _iter650.write(oprot);
             }
           }
         }
@@ -52760,14 +52901,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(1);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list643 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.new_parts = new ArrayList<PartitionSpec>(_list643.size);
-            PartitionSpec _elem644;
-            for (int _i645 = 0; _i645 < _list643.size; ++_i645)
+            org.apache.thrift.protocol.TList _list651 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.new_parts = new ArrayList<PartitionSpec>(_list651.size);
+            PartitionSpec _elem652;
+            for (int _i653 = 0; _i653 < _list651.size; ++_i653)
             {
-              _elem644 = new PartitionSpec();
-              _elem644.read(iprot);
-              struct.new_parts.add(_elem644);
+              _elem652 = new PartitionSpec();
+              _elem652.read(iprot);
+              struct.new_parts.add(_elem652);
             }
           }
           struct.setNew_partsIsSet(true);
@@ -53943,13 +54084,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list646 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list646.size);
-                  String _elem647;
-                  for (int _i648 = 0; _i648 < _list646.size; ++_i648)
+                  org.apache.thrift.protocol.TList _list654 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list654.size);
+                  String _elem655;
+                  for (int _i656 = 0; _i656 < _list654.size; ++_i656)
                   {
-                    _elem647 = iprot.readString();
-                    struct.part_vals.add(_elem647);
+                    _elem655 = iprot.readString();
+                    struct.part_vals.add(_elem655);
                   }
                   iprot.readListEnd();
                 }
@@ -53985,9 +54126,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter649 : struct.part_vals)
+            for (String _iter657 : struct.part_vals)
             {
-              oprot.writeString(_iter649);
+              oprot.writeString(_iter657);
             }
             oprot.writeListEnd();
           }
@@ -54030,9 +54171,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter650 : struct.part_vals)
+            for (String _iter658 : struct.part_vals)
             {
-              oprot.writeString(_iter650);
+              oprot.writeString(_iter658);
             }
           }
         }
@@ -54052,13 +54193,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list651 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list651.size);
-            String _elem652;
-            for (int _i653 = 0; _i653 < _list651.size; ++_i653)
+            org.apache.thrift.protocol.TList _list659 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list659.size);
+            String _elem660;
+            for (int _i661 = 0; _i661 < _list659.size; ++_i661)
             {
-              _elem652 = iprot.readString();
-              struct.part_vals.add(_elem652);
+              _elem660 = iprot.readString();
+              struct.part_vals.add(_elem660);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -56367,13 +56508,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list654 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list654.size);
-                  String _elem655;
-                  for (int _i656 = 0; _i656 < _list654.size; ++_i656)
+                  org.apache.thrift.protocol.TList _list662 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list662.size);
+                  String _elem663;
+                  for (int _i664 = 0; _i664 < _list662.size; ++_i664)
                   {
-                    _elem655 = iprot.readString();
-                    struct.part_vals.add(_elem655);
+                    _elem663 = iprot.readString();
+                    struct.part_vals.add(_elem663);
                   }
                   iprot.readListEnd();
                 }
@@ -56418,9 +56559,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter657 : struct.part_vals)
+            for (String _iter665 : struct.part_vals)
             {
-              oprot.writeString(_iter657);
+              oprot.writeString(_iter665);
             }
             oprot.writeListEnd();
           }
@@ -56471,9 +56612,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter658 : struct.part_vals)
+            for (String _iter666 : struct.part_vals)
             {
-              oprot.writeString(_iter658);
+              oprot.writeString(_iter666);
             }
           }
         }
@@ -56496,13 +56637,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list659 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list659.size);
-            String _elem660;
-            for (int _i661 = 0; _i661 < _list659.size; ++_i661)
+            org.apache.thrift.protocol.TList _list667 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list667.size);
+            String _elem668;
+            for (int _i669 = 0; _i669 < _list667.size; ++_i669)
             {
-              _elem660 = iprot.readString();
-              struct.part_vals.add(_elem660);
+              _elem668 = iprot.readString();
+              struct.part_vals.add(_elem668);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -60372,13 +60513,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list662 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list662.size);
-                  String _elem663;
-                  for (int _i664 = 0; _i664 < _list662.size; ++_i664)
+                  org.apache.thrift.protocol.TList _list670 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list670.size);
+                  String _elem671;
+                  for (int _i672 = 0; _i672 < _list670.size; ++_i672)
                   {
-                    _elem663 = iprot.readString();
-                    struct.part_vals.add(_elem663);
+                    _elem671 = iprot.readString();
+                    struct.part_vals.add(_elem671);
                   }
                   iprot.readListEnd();
                 }
@@ -60422,9 +60563,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter665 : struct.part_vals)
+            for (String _iter673 : struct.part_vals)
             {
-              oprot.writeString(_iter665);
+              oprot.writeString(_iter673);
             }
             oprot.writeListEnd();
           }
@@ -60473,9 +60614,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter666 : struct.part_vals)
+            for (String _iter674 : struct.part_vals)
             {
-              oprot.writeString(_iter666);
+              oprot.writeString(_iter674);
             }
           }
         }
@@ -60498,13 +60639,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list667 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list667.size);
-            String _elem668;
-            for (int _i669 = 0; _i669 < _list667.size; ++_i669)
+            org.apache.thrift.protocol.TList _list675 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list675.size);
+            String _elem676;
+            for (int _i677 = 0; _i677 < _list675.size; ++_i677)
             {
-              _elem668 = iprot.readString();
-              struct.part_vals.add(_elem668);
+              _elem676 = iprot.readString();
+              struct.part_vals.add(_elem676);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -61743,13 +61884,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list670 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list670.size);
-                  String _elem671;
-                  for (int _i672 = 0; _i672 < _list670.size; ++_i672)
+                  org.apache.thrift.protocol.TList _list678 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list678.size);
+                  String _elem679;
+                  for (int _i680 = 0; _i680 < _list678.size; ++_i680)
                   {
-                    _elem671 = iprot.readString();
-                    struct.part_vals.add(_elem671);
+                    _elem679 = iprot.readString();
+                    struct.part_vals.add(_elem679);
                   }
                   iprot.readListEnd();
                 }
@@ -61802,9 +61943,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter673 : struct.part_vals)
+            for (String _iter681 : struct.part_vals)
             {
-              oprot.writeString(_iter673);
+              oprot.writeString(_iter681);
             }
             oprot.writeListEnd();
           }
@@ -61861,9 +62002,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter674 : struct.part_vals)
+            for (String _iter682 : struct.part_vals)
             {
-              oprot.writeString(_iter674);
+              oprot.writeString(_iter682);
             }
           }
         }
@@ -61889,13 +62030,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list675 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list675.size);
-            String _elem676;
-            for (int _i677 = 0; _i677 < _list675.size; ++_i677)
+            org.apache.thrift.protocol.TList _list683 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list683.size);
+            String _elem684;
+            for (int _i685 = 0; _i685 < _list683.size; ++_i685)
             {
-              _elem676 = iprot.readString();
-              struct.part_vals.add(_elem676);
+              _elem684 = iprot.readString();
+              struct.part_vals.add(_elem684);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -66497,13 +66638,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list678 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list678.size);
-                  String _elem679;
-                  for (int _i680 = 0; _i680 < _list678.size; ++_i680)
+                  org.apache.thrift.protocol.TList _list686 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list686.size);
+                  String _elem687;
+                  for (int _i688 = 0; _i688 < _list686.size; ++_i688)
                   {
-                    _elem679 = iprot.readString();
-                    struct.part_vals.add(_elem679);
+                    _elem687 = iprot.readString();
+                    struct.part_vals.add(_elem687);
                   }
                   iprot.readListEnd();
                 }
@@ -66539,9 +66680,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter681 : struct.part_vals)
+            for (String _iter689 : struct.part_vals)
             {
-              oprot.writeString(_iter681);
+              oprot.writeString(_iter689);
             }
             oprot.writeListEnd();
           }
@@ -66584,9 +66725,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter682 : struct.part_vals)
+            for (String _iter690 : struct.part_vals)
             {
-              oprot.writeString(_iter682);
+              oprot.writeString(_iter690);
             }
           }
         }
@@ -66606,13 +66747,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list683 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list683.size);
-            String _elem684;
-            for (int _i685 = 0; _i685 < _list683.size; ++_i685)
+            org.apache.thrift.protocol.TList _list691 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list691.size);
+            String _elem692;
+            for (int _i693 = 0; _i693 < _list691.size; ++_i693)
             {
-              _elem684 = iprot.readString();
-              struct.part_vals.add(_elem684);
+              _elem692 = iprot.readString();
+              struct.part_vals.add(_elem692);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -67830,15 +67971,15 @@ public class ThriftHiveMetastore {
             case 1: // PARTITION_SPECS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map686 = iprot.readMapBegin();
-                  struct.partitionSpecs = new HashMap<String,String>(2*_map686.size);
-                  String _key687;
-                  String _val688;
-                  for (int _i689 = 0; _i689 < _map686.size; ++_i689)
+                  org.apache.thrift.protocol.TMap _map694 = iprot.readMapBegin();
+                  struct.partitionSpecs = new HashMap<String,String>(2*_map694.size);
+                  String _key695;
+                  String _val696;
+                  for (int _i697 = 0; _i697 < _map694.size; ++_i697)
                   {
-                    _key687 = iprot.readString();
-                    _val688 = iprot.readString();
-                    struct.partitionSpecs.put(_key687, _val688);
+                    _key695 = iprot.readString();
+                    _val696 = iprot.readString();
+                    struct.partitionSpecs.put(_key695, _val696);
                   }
                   iprot.readMapEnd();
                 }
@@ -67896,10 +68037,10 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PARTITION_SPECS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.partitionSpecs.size()));
-            for (Map.Entry<String, String> _iter690 : struct.partitionSpecs.entrySet())
+            for (Map.Entry<String, String> _iter698 : struct.partitionSpecs.entrySet())
             {
-              oprot.writeString(_iter690.getKey());
-              oprot.writeString(_iter690.getValue());
+              oprot.writeString(_iter698.getKey());
+              oprot.writeString(_iter698.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -67962,10 +68103,10 @@ public class ThriftHiveMetastore {
         if (struct.isSetPartitionSpecs()) {
           {
             oprot.writeI32(struct.partitionSpecs.size());
-            for (Map.Entry<String, String> _iter691 : struct.partitionSpecs.entrySet())
+            for (Map.Entry<String, String> _iter699 : struct.partitionSpecs.entrySet())
             {
-              oprot.writeString(_iter691.getKey());
-              oprot.writeString(_iter691.getValue());
+              oprot.writeString(_iter699.getKey());
+              oprot.writeString(_iter699.getValue());
             }
           }
         }
@@ -67989,15 +68130,15 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(5);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map692 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.partitionSpecs = new HashMap<String,String>(2*_map692.size);
-            String _key693;
-            String _val694;
-            for (int _i695 = 0; _i695 < _map692.size; ++_i695)
+            org.apache.thrift.protocol.TMap _map700 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.partitionSpecs = new HashMap<String,String>(2*_map700.size);
+            String _key701;
+            String _val702;
+            for (int _i703 = 0; _i703 < _map700.size; ++_i703)
             {
-              _key693 = iprot.readString();
-              _val694 = iprot.readString();
-              struct.partitionSpecs.put(_key693, _val694);
+              _key701 = iprot.readString();
+              _val702 = iprot.readString();
+              struct.partitionSpecs.put(_key701, _val702);
             }
           }
           struct.setPartitionSpecsIsSet(true);
@@ -69443,15 +69584,15 @@ public class ThriftHiveMetastore {
             case 1: // PARTITION_SPECS
               if (schemeField.type == org.apache.thrift.protocol.TType.MAP) {
                 {
-                  org.apache.thrift.protocol.TMap _map696 = iprot.readMapBegin();
-                  struct.partitionSpecs = new HashMap<String,String>(2*_map696.size);
-                  String _key697;
-                  String _val698;
-                  for (int _i699 = 0; _i699 < _map696.size; ++_i699)
+                  org.apache.thrift.protocol.TMap _map704 = iprot.readMapBegin();
+                  struct.partitionSpecs = new HashMap<String,String>(2*_map704.size);
+                  String _key705;
+                  String _val706;
+                  for (int _i707 = 0; _i707 < _map704.size; ++_i707)
                   {
-                    _key697 = iprot.readString();
-                    _val698 = iprot.readString();
-                    struct.partitionSpecs.put(_key697, _val698);
+                    _key705 = iprot.readString();
+                    _val706 = iprot.readString();
+                    struct.partitionSpecs.put(_key705, _val706);
                   }
                   iprot.readMapEnd();
                 }
@@ -69509,10 +69650,10 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PARTITION_SPECS_FIELD_DESC);
           {
             oprot.writeMapBegin(new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, struct.partitionSpecs.size()));
-            for (Map.Entry<String, String> _iter700 : struct.partitionSpecs.entrySet())
+            for (Map.Entry<String, String> _iter708 : struct.partitionSpecs.entrySet())
             {
-              oprot.writeString(_iter700.getKey());
-              oprot.writeString(_iter700.getValue());
+              oprot.writeString(_iter708.getKey());
+              oprot.writeString(_iter708.getValue());
             }
             oprot.writeMapEnd();
           }
@@ -69575,10 +69716,10 @@ public class ThriftHiveMetastore {
         if (struct.isSetPartitionSpecs()) {
           {
             oprot.writeI32(struct.partitionSpecs.size());
-            for (Map.Entry<String, String> _iter701 : struct.partitionSpecs.entrySet())
+            for (Map.Entry<String, String> _iter709 : struct.partitionSpecs.entrySet())
             {
-              oprot.writeString(_iter701.getKey());
-              oprot.writeString(_iter701.getValue());
+              oprot.writeString(_iter709.getKey());
+              oprot.writeString(_iter709.getValue());
             }
           }
         }
@@ -69602,15 +69743,15 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(5);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TMap _map702 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.partitionSpecs = new HashMap<String,String>(2*_map702.size);
-            String _key703;
-            String _val704;
-            for (int _i705 = 0; _i705 < _map702.size; ++_i705)
+            org.apache.thrift.protocol.TMap _map710 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.partitionSpecs = new HashMap<String,String>(2*_map710.size);
+            String _key711;
+            String _val712;
+            for (int _i713 = 0; _i713 < _map710.size; ++_i713)
             {
-              _key703 = iprot.readString();
-              _val704 = iprot.readString();
-              struct.partitionSpecs.put(_key703, _val704);
+              _key711 = iprot.readString();
+              _val712 = iprot.readString();
+              struct.partitionSpecs.put(_key711, _val712);
             }
           }
           struct.setPartitionSpecsIsSet(true);
@@ -70275,14 +70416,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list706 = iprot.readListBegin();
-                  struct.success = new ArrayList<Partition>(_list706.size);
-                  Partition _elem707;
-                  for (int _i708 = 0; _i708 < _list706.size; ++_i708)
+                  org.apache.thrift.protocol.TList _list714 = iprot.readListBegin();
+                  struct.success = new ArrayList<Partition>(_list714.size);
+                  Partition _elem715;
+                  for (int _i716 = 0; _i716 < _list714.size; ++_i716)
                   {
-                    _elem707 = new Partition();
-                    _elem707.read(iprot);
-                    struct.success.add(_elem707);
+                    _elem715 = new Partition();
+                    _elem715.read(iprot);
+                    struct.success.add(_elem715);
                   }
                   iprot.readListEnd();
                 }
@@ -70344,9 +70485,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (Partition _iter709 : struct.success)
+            for (Partition _iter717 : struct.success)
             {
-              _iter709.write(oprot);
+              _iter717.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -70409,9 +70550,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (Partition _iter710 : struct.success)
+            for (Partition _iter718 : struct.success)
             {
-              _iter710.write(oprot);
+              _iter718.write(oprot);
             }
           }
         }
@@ -70435,14 +70576,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(5);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list711 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<Partition>(_list711.size);
-            Partition _elem712;
-            for (int _i713 = 0; _i713 < _list711.size; ++_i713)
+            org.apache.thrift.protocol.TList _list719 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<Partition>(_list719.size);
+            Partition _elem720;
+            for (int _i721 = 0; _i721 < _list719.size; ++_i721)
             {
-              _elem712 = new Partition();
-              _elem712.read(iprot);
-              struct.success.add(_elem712);
+              _elem720 = new Partition();
+              _elem720.read(iprot);
+              struct.success.add(_elem720);
             }
           }
           struct.setSuccessIsSet(true);
@@ -71141,13 +71282,13 @@ public class ThriftHiveMetastore {
             case 3: // PART_VALS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list714 = iprot.readListBegin();
-                  struct.part_vals = new ArrayList<String>(_list714.size);
-                  String _elem715;
-                  for (int _i716 = 0; _i716 < _list714.size; ++_i716)
+                  org.apache.thrift.protocol.TList _list722 = iprot.readListBegin();
+                  struct.part_vals = new ArrayList<String>(_list722.size);
+                  String _elem723;
+                  for (int _i724 = 0; _i724 < _list722.size; ++_i724)
                   {
-                    _elem715 = iprot.readString();
-                    struct.part_vals.add(_elem715);
+                    _elem723 = iprot.readString();
+                    struct.part_vals.add(_elem723);
                   }
                   iprot.readListEnd();
                 }
@@ -71167,13 +71308,13 @@ public class ThriftHiveMetastore {
             case 5: // GROUP_NAMES
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list717 = iprot.readListBegin();
-                  struct.group_names = new ArrayList<String>(_list717.size);
-                  String _elem718;
-                  for (int _i719 = 0; _i719 < _list717.size; ++_i719)
+                  org.apache.thrift.protocol.TList _list725 = iprot.readListBegin();
+                  struct.group_names = new ArrayList<String>(_list725.size);
+                  String _elem726;
+                  for (int _i727 = 0; _i727 < _list725.size; ++_i727)
                   {
-                    _elem718 = iprot.readString();
-                    struct.group_names.add(_elem718);
+                    _elem726 = iprot.readString();
+                    struct.group_names.add(_elem726);
                   }
                   iprot.readListEnd();
                 }
@@ -71209,9 +71350,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(PART_VALS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.part_vals.size()));
-            for (String _iter720 : struct.part_vals)
+            for (String _iter728 : struct.part_vals)
             {
-              oprot.writeString(_iter720);
+              oprot.writeString(_iter728);
             }
             oprot.writeListEnd();
           }
@@ -71226,9 +71367,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(GROUP_NAMES_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, struct.group_names.size()));
-            for (String _iter721 : struct.group_names)
+            for (String _iter729 : struct.group_names)
             {
-              oprot.writeString(_iter721);
+              oprot.writeString(_iter729);
             }
             oprot.writeListEnd();
           }
@@ -71277,9 +71418,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetPart_vals()) {
           {
             oprot.writeI32(struct.part_vals.size());
-            for (String _iter722 : struct.part_vals)
+            for (String _iter730 : struct.part_vals)
             {
-              oprot.writeString(_iter722);
+              oprot.writeString(_iter730);
             }
           }
         }
@@ -71289,9 +71430,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetGroup_names()) {
           {
             oprot.writeI32(struct.group_names.size());
-            for (String _iter723 : struct.group_names)
+            for (String _iter731 : struct.group_names)
             {
-              oprot.writeString(_iter723);
+              oprot.writeString(_iter731);
             }
           }
         }
@@ -71311,13 +71452,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(2)) {
           {
-            org.apache.thrift.protocol.TList _list724 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.part_vals = new ArrayList<String>(_list724.size);
-            String _elem725;
-            for (int _i726 = 0; _i726 < _list724.size; ++_i726)
+            org.apache.thrift.protocol.TList _list732 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.part_vals = new ArrayList<String>(_list732.size);
+            String _elem733;
+            for (int _i734 = 0; _i734 < _list732.size; ++_i734)
             {
-              _elem725 = iprot.readString();
-              struct.part_vals.add(_elem725);
+              _elem733 = iprot.readString();
+              struct.part_vals.add(_elem733);
             }
           }
           struct.setPart_valsIsSet(true);
@@ -71328,13 +71469,13 @@ public class ThriftHiveMetastore {
         }
         if (incoming.get(4)) {
           {
-            org.apache.thrift.protocol.TList _list727 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
-            struct.group_names = new ArrayList<String>(_list727.size);
-            String _elem728;
-            for (int _i729 = 0; _i729 < _list727.size; ++_i729)
+            org.apache.thrift.protocol.TList _list735 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32());
+            struct.group_names = new ArrayList<String>(_list735.size);
+            String _elem736;
+            for (int _i737 = 0; _i737 < _list735.size; ++_i737)
             {
-              _elem728 = iprot.readString();
-              struct.group_names.add(_elem728);
+              _elem736 = iprot.readString();
+              struct.group_names.add(_elem736);
             }
           }
           struct.setGroup_namesIsSet(true);
@@ -74103,14 +74244,14 @@ public class ThriftHiveMetastore {
             case 0: // SUCCESS
               if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                 {
-                  org.apache.thrift.protocol.TList _list730 = iprot.readListBegin();
-                  struct.success = new ArrayList<Partition>(_list730.size);
-                  Partition _elem731;
-                  for (int _i732 = 0; _i732 < _list730.size; ++_i732)
+                  org.apache.thrift.protocol.TList _list738 = iprot.readListBegin();
+                  struct.success = new ArrayList<Partition>(_list738.size);
+                  Partition _elem739;
+                  for (int _i740 = 0; _i740 < _list738.size; ++_i740)
                   {
-                    _elem731 = new Partition();
-                    _elem731.read(iprot);
-                    struct.success.add(_elem731);
+                    _elem739 = new Partition();
+                    _elem739.read(iprot);
+                    struct.success.add(_elem739);
                   }
                   iprot.readListEnd();
                 }
@@ -74154,9 +74295,9 @@ public class ThriftHiveMetastore {
           oprot.writeFieldBegin(SUCCESS_FIELD_DESC);
           {
             oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.success.size()));
-            for (Partition _iter733 : struct.success)
+            for (Partition _iter741 : struct.success)
             {
-              _iter733.write(oprot);
+              _iter741.write(oprot);
             }
             oprot.writeListEnd();
           }
@@ -74203,9 +74344,9 @@ public class ThriftHiveMetastore {
         if (struct.isSetSuccess()) {
           {
             oprot.writeI32(struct.success.size());
-            for (Partition _iter734 : struct.success)
+            for (Partition _iter742 : struct.success)
             {
-              _iter734.write(oprot);
+              _iter742.write(oprot);
             }
           }
         }
@@ -74223,14 +74364,14 @@ public class ThriftHiveMetastore {
         BitSet incoming = iprot.readBitSet(3);
         if (incoming.get(0)) {
           {
-            org.apache.thrift.protocol.TList _list735 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-            struct.success = new ArrayList<Partition>(_list735.size);
-            Partition _elem736;
-            for (int _i737 = 0; _i737 < _list735.size; ++_i737)
+            org.apache.thrift.protocol.TList _list743 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
+            struct.success = new ArrayList<Partition>(_list743.size);
+            Partition _elem744;
+            for (int _i745 = 0; _i745 < _list743.size; ++_i745)
             {
-              _elem736 = new Partition();
-              _elem736.read(iprot);
-              struct.success.add(_elem736);
+ 

<TRUNCATED>