Return-Path: X-Original-To: apmail-hive-commits-archive@www.apache.org Delivered-To: apmail-hive-commits-archive@www.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 9189E10E81 for ; Wed, 5 Mar 2014 00:21:55 +0000 (UTC) Received: (qmail 57103 invoked by uid 500); 5 Mar 2014 00:21:54 -0000 Delivered-To: apmail-hive-commits-archive@hive.apache.org Received: (qmail 56989 invoked by uid 500); 5 Mar 2014 00:21:54 -0000 Mailing-List: contact commits-help@hive.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: hive-dev@hive.apache.org Delivered-To: mailing list commits@hive.apache.org Received: (qmail 56698 invoked by uid 99); 5 Mar 2014 00:21:53 -0000 Received: from athena.apache.org (HELO athena.apache.org) (140.211.11.136) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 05 Mar 2014 00:21:53 +0000 X-ASF-Spam-Status: No, hits=-2000.0 required=5.0 tests=ALL_TRUSTED X-Spam-Check-By: apache.org Received: from [140.211.11.4] (HELO eris.apache.org) (140.211.11.4) by apache.org (qpsmtpd/0.29) with ESMTP; Wed, 05 Mar 2014 00:21:49 +0000 Received: from eris.apache.org (localhost [127.0.0.1]) by eris.apache.org (Postfix) with ESMTP id 4B1122388C7D; Wed, 5 Mar 2014 00:21:05 +0000 (UTC) Content-Type: text/plain; charset="utf-8" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit Subject: svn commit: r1574266 [12/23] - in /hive/trunk: common/src/java/org/apache/hadoop/hive/conf/ itests/hive-unit/src/test/java/org/apache/hadoop/hive/metastore/ metastore/ metastore/if/ metastore/scripts/upgrade/derby/ metastore/scripts/upgrade/mysql/ meta... Date: Wed, 05 Mar 2014 00:20:57 -0000 To: commits@hive.apache.org From: hashutosh@apache.org X-Mailer: svnmailer-1.0.9 Message-Id: <20140305002105.4B1122388C7D@eris.apache.org> X-Virus-Checked: Checked by ClamAV on apache.org Modified: hive/trunk/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java URL: http://svn.apache.org/viewvc/hive/trunk/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java?rev=1574266&r1=1574265&r2=1574266&view=diff ============================================================================== --- hive/trunk/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java (original) +++ hive/trunk/metastore/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/ThriftHiveMetastore.java Wed Mar 5 00:20:53 2014 @@ -222,6 +222,30 @@ public class ThriftHiveMetastore { public void cancel_delegation_token(String token_str_form) throws MetaException, org.apache.thrift.TException; + public GetOpenTxnsResponse get_open_txns() throws org.apache.thrift.TException; + + public GetOpenTxnsInfoResponse get_open_txns_info() throws org.apache.thrift.TException; + + public OpenTxnsResponse open_txns(OpenTxnRequest rqst) throws org.apache.thrift.TException; + + public void abort_txn(AbortTxnRequest 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; + + public LockResponse check_lock(CheckLockRequest rqst) throws NoSuchTxnException, TxnAbortedException, NoSuchLockException, org.apache.thrift.TException; + + public void unlock(UnlockRequest rqst) throws NoSuchLockException, TxnOpenException, org.apache.thrift.TException; + + public ShowLocksResponse show_locks(ShowLocksRequest rqst) throws org.apache.thrift.TException; + + public void heartbeat(HeartbeatRequest ids) throws NoSuchLockException, NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException; + + public void compact(CompactionRequest rqst) throws org.apache.thrift.TException; + + public ShowCompactResponse show_compact(ShowCompactRequest rqst) throws org.apache.thrift.TException; + } public interface AsyncIface extends com.facebook.fb303.FacebookService .AsyncIface { @@ -410,6 +434,30 @@ public class ThriftHiveMetastore { public void cancel_delegation_token(String token_str_form, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + public void get_open_txns(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void get_open_txns_info(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void open_txns(OpenTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void abort_txn(AbortTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void commit_txn(CommitTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void lock(LockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void check_lock(CheckLockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void unlock(UnlockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void show_locks(ShowLocksRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void heartbeat(HeartbeatRequest ids, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void compact(CompactionRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + + public void show_compact(ShowCompactRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException; + } public static class Client extends com.facebook.fb303.FacebookService.Client implements Iface { @@ -3237,6 +3285,304 @@ public class ThriftHiveMetastore { return; } + public GetOpenTxnsResponse get_open_txns() throws org.apache.thrift.TException + { + send_get_open_txns(); + return recv_get_open_txns(); + } + + public void send_get_open_txns() throws org.apache.thrift.TException + { + get_open_txns_args args = new get_open_txns_args(); + sendBase("get_open_txns", args); + } + + public GetOpenTxnsResponse recv_get_open_txns() throws org.apache.thrift.TException + { + get_open_txns_result result = new get_open_txns_result(); + receiveBase(result, "get_open_txns"); + if (result.isSetSuccess()) { + return result.success; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_open_txns failed: unknown result"); + } + + public GetOpenTxnsInfoResponse get_open_txns_info() throws org.apache.thrift.TException + { + send_get_open_txns_info(); + return recv_get_open_txns_info(); + } + + public void send_get_open_txns_info() throws org.apache.thrift.TException + { + get_open_txns_info_args args = new get_open_txns_info_args(); + sendBase("get_open_txns_info", args); + } + + public GetOpenTxnsInfoResponse recv_get_open_txns_info() throws org.apache.thrift.TException + { + get_open_txns_info_result result = new get_open_txns_info_result(); + receiveBase(result, "get_open_txns_info"); + if (result.isSetSuccess()) { + return result.success; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "get_open_txns_info failed: unknown result"); + } + + public OpenTxnsResponse open_txns(OpenTxnRequest rqst) throws org.apache.thrift.TException + { + send_open_txns(rqst); + return recv_open_txns(); + } + + public void send_open_txns(OpenTxnRequest rqst) throws org.apache.thrift.TException + { + open_txns_args args = new open_txns_args(); + args.setRqst(rqst); + sendBase("open_txns", args); + } + + public OpenTxnsResponse recv_open_txns() throws org.apache.thrift.TException + { + open_txns_result result = new open_txns_result(); + receiveBase(result, "open_txns"); + if (result.isSetSuccess()) { + return result.success; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "open_txns failed: unknown result"); + } + + public void abort_txn(AbortTxnRequest rqst) throws NoSuchTxnException, org.apache.thrift.TException + { + send_abort_txn(rqst); + recv_abort_txn(); + } + + public void send_abort_txn(AbortTxnRequest rqst) throws org.apache.thrift.TException + { + abort_txn_args args = new abort_txn_args(); + args.setRqst(rqst); + sendBase("abort_txn", args); + } + + public void recv_abort_txn() throws NoSuchTxnException, org.apache.thrift.TException + { + abort_txn_result result = new abort_txn_result(); + receiveBase(result, "abort_txn"); + 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); + recv_commit_txn(); + } + + public void send_commit_txn(CommitTxnRequest rqst) throws org.apache.thrift.TException + { + commit_txn_args args = new commit_txn_args(); + args.setRqst(rqst); + sendBase("commit_txn", args); + } + + public void recv_commit_txn() throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException + { + commit_txn_result result = new commit_txn_result(); + receiveBase(result, "commit_txn"); + if (result.o1 != null) { + throw result.o1; + } + if (result.o2 != null) { + throw result.o2; + } + return; + } + + public LockResponse lock(LockRequest rqst) throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException + { + send_lock(rqst); + return recv_lock(); + } + + public void send_lock(LockRequest rqst) throws org.apache.thrift.TException + { + lock_args args = new lock_args(); + args.setRqst(rqst); + sendBase("lock", args); + } + + public LockResponse recv_lock() throws NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException + { + lock_result result = new lock_result(); + receiveBase(result, "lock"); + if (result.isSetSuccess()) { + return result.success; + } + if (result.o1 != null) { + throw result.o1; + } + if (result.o2 != null) { + throw result.o2; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "lock failed: unknown result"); + } + + public LockResponse check_lock(CheckLockRequest rqst) throws NoSuchTxnException, TxnAbortedException, NoSuchLockException, org.apache.thrift.TException + { + send_check_lock(rqst); + return recv_check_lock(); + } + + public void send_check_lock(CheckLockRequest rqst) throws org.apache.thrift.TException + { + check_lock_args args = new check_lock_args(); + args.setRqst(rqst); + sendBase("check_lock", args); + } + + public LockResponse recv_check_lock() throws NoSuchTxnException, TxnAbortedException, NoSuchLockException, org.apache.thrift.TException + { + check_lock_result result = new check_lock_result(); + receiveBase(result, "check_lock"); + if (result.isSetSuccess()) { + return result.success; + } + if (result.o1 != null) { + throw result.o1; + } + if (result.o2 != null) { + throw result.o2; + } + if (result.o3 != null) { + throw result.o3; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "check_lock failed: unknown result"); + } + + public void unlock(UnlockRequest rqst) throws NoSuchLockException, TxnOpenException, org.apache.thrift.TException + { + send_unlock(rqst); + recv_unlock(); + } + + public void send_unlock(UnlockRequest rqst) throws org.apache.thrift.TException + { + unlock_args args = new unlock_args(); + args.setRqst(rqst); + sendBase("unlock", args); + } + + public void recv_unlock() throws NoSuchLockException, TxnOpenException, org.apache.thrift.TException + { + unlock_result result = new unlock_result(); + receiveBase(result, "unlock"); + if (result.o1 != null) { + throw result.o1; + } + if (result.o2 != null) { + throw result.o2; + } + return; + } + + public ShowLocksResponse show_locks(ShowLocksRequest rqst) throws org.apache.thrift.TException + { + send_show_locks(rqst); + return recv_show_locks(); + } + + public void send_show_locks(ShowLocksRequest rqst) throws org.apache.thrift.TException + { + show_locks_args args = new show_locks_args(); + args.setRqst(rqst); + sendBase("show_locks", args); + } + + public ShowLocksResponse recv_show_locks() throws org.apache.thrift.TException + { + show_locks_result result = new show_locks_result(); + receiveBase(result, "show_locks"); + if (result.isSetSuccess()) { + return result.success; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "show_locks failed: unknown result"); + } + + public void heartbeat(HeartbeatRequest ids) throws NoSuchLockException, NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException + { + send_heartbeat(ids); + recv_heartbeat(); + } + + public void send_heartbeat(HeartbeatRequest ids) throws org.apache.thrift.TException + { + heartbeat_args args = new heartbeat_args(); + args.setIds(ids); + sendBase("heartbeat", args); + } + + public void recv_heartbeat() throws NoSuchLockException, NoSuchTxnException, TxnAbortedException, org.apache.thrift.TException + { + heartbeat_result result = new heartbeat_result(); + receiveBase(result, "heartbeat"); + if (result.o1 != null) { + throw result.o1; + } + if (result.o2 != null) { + throw result.o2; + } + if (result.o3 != null) { + throw result.o3; + } + return; + } + + public void compact(CompactionRequest rqst) throws org.apache.thrift.TException + { + send_compact(rqst); + recv_compact(); + } + + public void send_compact(CompactionRequest rqst) throws org.apache.thrift.TException + { + compact_args args = new compact_args(); + args.setRqst(rqst); + sendBase("compact", args); + } + + public void recv_compact() throws org.apache.thrift.TException + { + compact_result result = new compact_result(); + receiveBase(result, "compact"); + return; + } + + public ShowCompactResponse show_compact(ShowCompactRequest rqst) throws org.apache.thrift.TException + { + send_show_compact(rqst); + return recv_show_compact(); + } + + public void send_show_compact(ShowCompactRequest rqst) throws org.apache.thrift.TException + { + show_compact_args args = new show_compact_args(); + args.setRqst(rqst); + sendBase("show_compact", args); + } + + public ShowCompactResponse recv_show_compact() throws org.apache.thrift.TException + { + show_compact_result result = new show_compact_result(); + receiveBase(result, "show_compact"); + if (result.isSetSuccess()) { + return result.success; + } + throw new org.apache.thrift.TApplicationException(org.apache.thrift.TApplicationException.MISSING_RESULT, "show_compact failed: unknown result"); + } + } public static class AsyncClient extends com.facebook.fb303.FacebookService.AsyncClient implements AsyncIface { public static class Factory implements org.apache.thrift.async.TAsyncClientFactory { @@ -6619,6 +6965,384 @@ public class ThriftHiveMetastore { } } + public void get_open_txns(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + get_open_txns_call method_call = new get_open_txns_call(resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class get_open_txns_call extends org.apache.thrift.async.TAsyncMethodCall { + public get_open_txns_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { + super(client, protocolFactory, transport, resultHandler, false); + } + + public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { + prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("get_open_txns", org.apache.thrift.protocol.TMessageType.CALL, 0)); + get_open_txns_args args = new get_open_txns_args(); + args.write(prot); + prot.writeMessageEnd(); + } + + public GetOpenTxnsResponse getResult() throws 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); + return (new Client(prot)).recv_get_open_txns(); + } + } + + public void get_open_txns_info(org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + get_open_txns_info_call method_call = new get_open_txns_info_call(resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class get_open_txns_info_call extends org.apache.thrift.async.TAsyncMethodCall { + public get_open_txns_info_call(org.apache.thrift.async.AsyncMethodCallback resultHandler, org.apache.thrift.async.TAsyncClient client, org.apache.thrift.protocol.TProtocolFactory protocolFactory, org.apache.thrift.transport.TNonblockingTransport transport) throws org.apache.thrift.TException { + super(client, protocolFactory, transport, resultHandler, false); + } + + public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { + prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("get_open_txns_info", org.apache.thrift.protocol.TMessageType.CALL, 0)); + get_open_txns_info_args args = new get_open_txns_info_args(); + args.write(prot); + prot.writeMessageEnd(); + } + + public GetOpenTxnsInfoResponse getResult() throws 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); + return (new Client(prot)).recv_get_open_txns_info(); + } + } + + public void open_txns(OpenTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + open_txns_call method_call = new open_txns_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class open_txns_call extends org.apache.thrift.async.TAsyncMethodCall { + private OpenTxnRequest rqst; + public open_txns_call(OpenTxnRequest 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("open_txns", org.apache.thrift.protocol.TMessageType.CALL, 0)); + open_txns_args args = new open_txns_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public OpenTxnsResponse getResult() throws 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); + return (new Client(prot)).recv_open_txns(); + } + } + + public void abort_txn(AbortTxnRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + abort_txn_call method_call = new abort_txn_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class abort_txn_call extends org.apache.thrift.async.TAsyncMethodCall { + private AbortTxnRequest rqst; + public abort_txn_call(AbortTxnRequest 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_txn", org.apache.thrift.protocol.TMessageType.CALL, 0)); + abort_txn_args args = new abort_txn_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_txn(); + } + } + + 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); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class commit_txn_call extends org.apache.thrift.async.TAsyncMethodCall { + private CommitTxnRequest rqst; + public commit_txn_call(CommitTxnRequest 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("commit_txn", org.apache.thrift.protocol.TMessageType.CALL, 0)); + commit_txn_args args = new commit_txn_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public void getResult() throws NoSuchTxnException, TxnAbortedException, 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_commit_txn(); + } + } + + public void lock(LockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + lock_call method_call = new lock_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class lock_call extends org.apache.thrift.async.TAsyncMethodCall { + private LockRequest rqst; + public lock_call(LockRequest 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("lock", org.apache.thrift.protocol.TMessageType.CALL, 0)); + lock_args args = new lock_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public LockResponse getResult() throws NoSuchTxnException, TxnAbortedException, 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); + return (new Client(prot)).recv_lock(); + } + } + + public void check_lock(CheckLockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + check_lock_call method_call = new check_lock_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class check_lock_call extends org.apache.thrift.async.TAsyncMethodCall { + private CheckLockRequest rqst; + public check_lock_call(CheckLockRequest 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("check_lock", org.apache.thrift.protocol.TMessageType.CALL, 0)); + check_lock_args args = new check_lock_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public LockResponse getResult() throws NoSuchTxnException, TxnAbortedException, NoSuchLockException, 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); + return (new Client(prot)).recv_check_lock(); + } + } + + public void unlock(UnlockRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + unlock_call method_call = new unlock_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class unlock_call extends org.apache.thrift.async.TAsyncMethodCall { + private UnlockRequest rqst; + public unlock_call(UnlockRequest 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("unlock", org.apache.thrift.protocol.TMessageType.CALL, 0)); + unlock_args args = new unlock_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public void getResult() throws NoSuchLockException, TxnOpenException, 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_unlock(); + } + } + + public void show_locks(ShowLocksRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + show_locks_call method_call = new show_locks_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class show_locks_call extends org.apache.thrift.async.TAsyncMethodCall { + private ShowLocksRequest rqst; + public show_locks_call(ShowLocksRequest 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("show_locks", org.apache.thrift.protocol.TMessageType.CALL, 0)); + show_locks_args args = new show_locks_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public ShowLocksResponse getResult() throws 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); + return (new Client(prot)).recv_show_locks(); + } + } + + public void heartbeat(HeartbeatRequest ids, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + heartbeat_call method_call = new heartbeat_call(ids, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class heartbeat_call extends org.apache.thrift.async.TAsyncMethodCall { + private HeartbeatRequest ids; + public heartbeat_call(HeartbeatRequest ids, 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.ids = ids; + } + + public void write_args(org.apache.thrift.protocol.TProtocol prot) throws org.apache.thrift.TException { + prot.writeMessageBegin(new org.apache.thrift.protocol.TMessage("heartbeat", org.apache.thrift.protocol.TMessageType.CALL, 0)); + heartbeat_args args = new heartbeat_args(); + args.setIds(ids); + args.write(prot); + prot.writeMessageEnd(); + } + + public void getResult() throws NoSuchLockException, NoSuchTxnException, TxnAbortedException, 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_heartbeat(); + } + } + + public void compact(CompactionRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + compact_call method_call = new compact_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class compact_call extends org.apache.thrift.async.TAsyncMethodCall { + private CompactionRequest rqst; + public compact_call(CompactionRequest 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("compact", org.apache.thrift.protocol.TMessageType.CALL, 0)); + compact_args args = new compact_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public void getResult() throws 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_compact(); + } + } + + public void show_compact(ShowCompactRequest rqst, org.apache.thrift.async.AsyncMethodCallback resultHandler) throws org.apache.thrift.TException { + checkReady(); + show_compact_call method_call = new show_compact_call(rqst, resultHandler, this, ___protocolFactory, ___transport); + this.___currentMethod = method_call; + ___manager.call(method_call); + } + + public static class show_compact_call extends org.apache.thrift.async.TAsyncMethodCall { + private ShowCompactRequest rqst; + public show_compact_call(ShowCompactRequest 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("show_compact", org.apache.thrift.protocol.TMessageType.CALL, 0)); + show_compact_args args = new show_compact_args(); + args.setRqst(rqst); + args.write(prot); + prot.writeMessageEnd(); + } + + public ShowCompactResponse getResult() throws 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); + return (new Client(prot)).recv_show_compact(); + } + } + } public static class Processor extends com.facebook.fb303.FacebookService.Processor implements org.apache.thrift.TProcessor { @@ -6724,6 +7448,18 @@ public class ThriftHiveMetastore { processMap.put("get_delegation_token", new get_delegation_token()); processMap.put("renew_delegation_token", new renew_delegation_token()); processMap.put("cancel_delegation_token", new cancel_delegation_token()); + processMap.put("get_open_txns", new get_open_txns()); + 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("commit_txn", new commit_txn()); + processMap.put("lock", new lock()); + processMap.put("check_lock", new check_lock()); + processMap.put("unlock", new unlock()); + processMap.put("show_locks", new show_locks()); + processMap.put("heartbeat", new heartbeat()); + processMap.put("compact", new compact()); + processMap.put("show_compact", new show_compact()); return processMap; } @@ -9176,75 +9912,353 @@ public class ThriftHiveMetastore { } } - } + public static class get_open_txns extends org.apache.thrift.ProcessFunction { + public get_open_txns() { + super("get_open_txns"); + } - public static class create_database_args implements org.apache.thrift.TBase, java.io.Serializable, Cloneable { - private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("create_database_args"); + public get_open_txns_args getEmptyArgsInstance() { + return new get_open_txns_args(); + } - private static final org.apache.thrift.protocol.TField DATABASE_FIELD_DESC = new org.apache.thrift.protocol.TField("database", org.apache.thrift.protocol.TType.STRUCT, (short)1); + protected boolean isOneway() { + return false; + } - private static final Map, SchemeFactory> schemes = new HashMap, SchemeFactory>(); - static { - schemes.put(StandardScheme.class, new create_database_argsStandardSchemeFactory()); - schemes.put(TupleScheme.class, new create_database_argsTupleSchemeFactory()); + public get_open_txns_result getResult(I iface, get_open_txns_args args) throws org.apache.thrift.TException { + get_open_txns_result result = new get_open_txns_result(); + result.success = iface.get_open_txns(); + return result; + } } - private Database database; // 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 { - DATABASE((short)1, "database"); - - private static final Map byName = new HashMap(); - - static { - for (_Fields field : EnumSet.allOf(_Fields.class)) { - byName.put(field.getFieldName(), field); - } + public static class get_open_txns_info extends org.apache.thrift.ProcessFunction { + public get_open_txns_info() { + super("get_open_txns_info"); } - /** - * Find the _Fields constant that matches fieldId, or null if its not found. - */ - public static _Fields findByThriftId(int fieldId) { - switch(fieldId) { - case 1: // DATABASE - return DATABASE; - default: - return null; - } + public get_open_txns_info_args getEmptyArgsInstance() { + return new get_open_txns_info_args(); } - /** - * 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; + protected boolean isOneway() { + return false; } - /** - * Find the _Fields constant that matches name, or null if its not found. - */ - public static _Fields findByName(String name) { - return byName.get(name); + public get_open_txns_info_result getResult(I iface, get_open_txns_info_args args) throws org.apache.thrift.TException { + get_open_txns_info_result result = new get_open_txns_info_result(); + result.success = iface.get_open_txns_info(); + return result; } + } - private final short _thriftId; - private final String _fieldName; - - _Fields(short thriftId, String fieldName) { - _thriftId = thriftId; - _fieldName = fieldName; + public static class open_txns extends org.apache.thrift.ProcessFunction { + public open_txns() { + super("open_txns"); } - public short getThriftFieldId() { - return _thriftId; + public open_txns_args getEmptyArgsInstance() { + return new open_txns_args(); } - public String getFieldName() { + protected boolean isOneway() { + return false; + } + + public open_txns_result getResult(I iface, open_txns_args args) throws org.apache.thrift.TException { + open_txns_result result = new open_txns_result(); + result.success = iface.open_txns(args.rqst); + return result; + } + } + + public static class abort_txn extends org.apache.thrift.ProcessFunction { + public abort_txn() { + super("abort_txn"); + } + + public abort_txn_args getEmptyArgsInstance() { + return new abort_txn_args(); + } + + protected boolean isOneway() { + return false; + } + + public abort_txn_result getResult(I iface, abort_txn_args args) throws org.apache.thrift.TException { + abort_txn_result result = new abort_txn_result(); + try { + iface.abort_txn(args.rqst); + } catch (NoSuchTxnException o1) { + result.o1 = o1; + } + return result; + } + } + + public static class commit_txn extends org.apache.thrift.ProcessFunction { + public commit_txn() { + super("commit_txn"); + } + + public commit_txn_args getEmptyArgsInstance() { + return new commit_txn_args(); + } + + protected boolean isOneway() { + return false; + } + + public commit_txn_result getResult(I iface, commit_txn_args args) throws org.apache.thrift.TException { + commit_txn_result result = new commit_txn_result(); + try { + iface.commit_txn(args.rqst); + } catch (NoSuchTxnException o1) { + result.o1 = o1; + } catch (TxnAbortedException o2) { + result.o2 = o2; + } + return result; + } + } + + public static class lock extends org.apache.thrift.ProcessFunction { + public lock() { + super("lock"); + } + + public lock_args getEmptyArgsInstance() { + return new lock_args(); + } + + protected boolean isOneway() { + return false; + } + + public lock_result getResult(I iface, lock_args args) throws org.apache.thrift.TException { + lock_result result = new lock_result(); + try { + result.success = iface.lock(args.rqst); + } catch (NoSuchTxnException o1) { + result.o1 = o1; + } catch (TxnAbortedException o2) { + result.o2 = o2; + } + return result; + } + } + + public static class check_lock extends org.apache.thrift.ProcessFunction { + public check_lock() { + super("check_lock"); + } + + public check_lock_args getEmptyArgsInstance() { + return new check_lock_args(); + } + + protected boolean isOneway() { + return false; + } + + public check_lock_result getResult(I iface, check_lock_args args) throws org.apache.thrift.TException { + check_lock_result result = new check_lock_result(); + try { + result.success = iface.check_lock(args.rqst); + } catch (NoSuchTxnException o1) { + result.o1 = o1; + } catch (TxnAbortedException o2) { + result.o2 = o2; + } catch (NoSuchLockException o3) { + result.o3 = o3; + } + return result; + } + } + + public static class unlock extends org.apache.thrift.ProcessFunction { + public unlock() { + super("unlock"); + } + + public unlock_args getEmptyArgsInstance() { + return new unlock_args(); + } + + protected boolean isOneway() { + return false; + } + + public unlock_result getResult(I iface, unlock_args args) throws org.apache.thrift.TException { + unlock_result result = new unlock_result(); + try { + iface.unlock(args.rqst); + } catch (NoSuchLockException o1) { + result.o1 = o1; + } catch (TxnOpenException o2) { + result.o2 = o2; + } + return result; + } + } + + public static class show_locks extends org.apache.thrift.ProcessFunction { + public show_locks() { + super("show_locks"); + } + + public show_locks_args getEmptyArgsInstance() { + return new show_locks_args(); + } + + protected boolean isOneway() { + return false; + } + + public show_locks_result getResult(I iface, show_locks_args args) throws org.apache.thrift.TException { + show_locks_result result = new show_locks_result(); + result.success = iface.show_locks(args.rqst); + return result; + } + } + + public static class heartbeat extends org.apache.thrift.ProcessFunction { + public heartbeat() { + super("heartbeat"); + } + + public heartbeat_args getEmptyArgsInstance() { + return new heartbeat_args(); + } + + protected boolean isOneway() { + return false; + } + + public heartbeat_result getResult(I iface, heartbeat_args args) throws org.apache.thrift.TException { + heartbeat_result result = new heartbeat_result(); + try { + iface.heartbeat(args.ids); + } catch (NoSuchLockException o1) { + result.o1 = o1; + } catch (NoSuchTxnException o2) { + result.o2 = o2; + } catch (TxnAbortedException o3) { + result.o3 = o3; + } + return result; + } + } + + public static class compact extends org.apache.thrift.ProcessFunction { + public compact() { + super("compact"); + } + + public compact_args getEmptyArgsInstance() { + return new compact_args(); + } + + protected boolean isOneway() { + return false; + } + + public compact_result getResult(I iface, compact_args args) throws org.apache.thrift.TException { + compact_result result = new compact_result(); + iface.compact(args.rqst); + return result; + } + } + + public static class show_compact extends org.apache.thrift.ProcessFunction { + public show_compact() { + super("show_compact"); + } + + public show_compact_args getEmptyArgsInstance() { + return new show_compact_args(); + } + + protected boolean isOneway() { + return false; + } + + public show_compact_result getResult(I iface, show_compact_args args) throws org.apache.thrift.TException { + show_compact_result result = new show_compact_result(); + result.success = iface.show_compact(args.rqst); + return result; + } + } + + } + + public static class create_database_args implements org.apache.thrift.TBase, java.io.Serializable, Cloneable { + private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("create_database_args"); + + private static final org.apache.thrift.protocol.TField DATABASE_FIELD_DESC = new org.apache.thrift.protocol.TField("database", org.apache.thrift.protocol.TType.STRUCT, (short)1); + + private static final Map, SchemeFactory> schemes = new HashMap, SchemeFactory>(); + static { + schemes.put(StandardScheme.class, new create_database_argsStandardSchemeFactory()); + schemes.put(TupleScheme.class, new create_database_argsTupleSchemeFactory()); + } + + private Database database; // 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 { + DATABASE((short)1, "database"); + + private static final Map byName = new HashMap(); + + 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: // DATABASE + return DATABASE; + 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; } } @@ -12930,13 +13944,13 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list362 = iprot.readListBegin(); - struct.success = new ArrayList(_list362.size); - for (int _i363 = 0; _i363 < _list362.size; ++_i363) + org.apache.thrift.protocol.TList _list410 = iprot.readListBegin(); + struct.success = new ArrayList(_list410.size); + for (int _i411 = 0; _i411 < _list410.size; ++_i411) { - String _elem364; // optional - _elem364 = iprot.readString(); - struct.success.add(_elem364); + String _elem412; // required + _elem412 = iprot.readString(); + struct.success.add(_elem412); } iprot.readListEnd(); } @@ -12971,9 +13985,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 _iter365 : struct.success) + for (String _iter413 : struct.success) { - oprot.writeString(_iter365); + oprot.writeString(_iter413); } oprot.writeListEnd(); } @@ -13012,9 +14026,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (String _iter366 : struct.success) + for (String _iter414 : struct.success) { - oprot.writeString(_iter366); + oprot.writeString(_iter414); } } } @@ -13029,13 +14043,13 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list367 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.success = new ArrayList(_list367.size); - for (int _i368 = 0; _i368 < _list367.size; ++_i368) + org.apache.thrift.protocol.TList _list415 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.success = new ArrayList(_list415.size); + for (int _i416 = 0; _i416 < _list415.size; ++_i416) { - String _elem369; // optional - _elem369 = iprot.readString(); - struct.success.add(_elem369); + String _elem417; // required + _elem417 = iprot.readString(); + struct.success.add(_elem417); } } struct.setSuccessIsSet(true); @@ -13692,13 +14706,13 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list370 = iprot.readListBegin(); - struct.success = new ArrayList(_list370.size); - for (int _i371 = 0; _i371 < _list370.size; ++_i371) + org.apache.thrift.protocol.TList _list418 = iprot.readListBegin(); + struct.success = new ArrayList(_list418.size); + for (int _i419 = 0; _i419 < _list418.size; ++_i419) { - String _elem372; // optional - _elem372 = iprot.readString(); - struct.success.add(_elem372); + String _elem420; // required + _elem420 = iprot.readString(); + struct.success.add(_elem420); } iprot.readListEnd(); } @@ -13733,9 +14747,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 _iter373 : struct.success) + for (String _iter421 : struct.success) { - oprot.writeString(_iter373); + oprot.writeString(_iter421); } oprot.writeListEnd(); } @@ -13774,9 +14788,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (String _iter374 : struct.success) + for (String _iter422 : struct.success) { - oprot.writeString(_iter374); + oprot.writeString(_iter422); } } } @@ -13791,13 +14805,13 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list375 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.success = new ArrayList(_list375.size); - for (int _i376 = 0; _i376 < _list375.size; ++_i376) + org.apache.thrift.protocol.TList _list423 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.success = new ArrayList(_list423.size); + for (int _i424 = 0; _i424 < _list423.size; ++_i424) { - String _elem377; // optional - _elem377 = iprot.readString(); - struct.success.add(_elem377); + String _elem425; // required + _elem425 = iprot.readString(); + struct.success.add(_elem425); } } struct.setSuccessIsSet(true); @@ -18404,16 +19418,16 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.MAP) { { - org.apache.thrift.protocol.TMap _map378 = iprot.readMapBegin(); - struct.success = new HashMap(2*_map378.size); - for (int _i379 = 0; _i379 < _map378.size; ++_i379) + org.apache.thrift.protocol.TMap _map426 = iprot.readMapBegin(); + struct.success = new HashMap(2*_map426.size); + for (int _i427 = 0; _i427 < _map426.size; ++_i427) { - String _key380; // required - Type _val381; // required - _key380 = iprot.readString(); - _val381 = new Type(); - _val381.read(iprot); - struct.success.put(_key380, _val381); + String _key428; // required + Type _val429; // required + _key428 = iprot.readString(); + _val429 = new Type(); + _val429.read(iprot); + struct.success.put(_key428, _val429); } iprot.readMapEnd(); } @@ -18448,10 +19462,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 _iter382 : struct.success.entrySet()) + for (Map.Entry _iter430 : struct.success.entrySet()) { - oprot.writeString(_iter382.getKey()); - _iter382.getValue().write(oprot); + oprot.writeString(_iter430.getKey()); + _iter430.getValue().write(oprot); } oprot.writeMapEnd(); } @@ -18490,10 +19504,10 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (Map.Entry _iter383 : struct.success.entrySet()) + for (Map.Entry _iter431 : struct.success.entrySet()) { - oprot.writeString(_iter383.getKey()); - _iter383.getValue().write(oprot); + oprot.writeString(_iter431.getKey()); + _iter431.getValue().write(oprot); } } } @@ -18508,16 +19522,16 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { - org.apache.thrift.protocol.TMap _map384 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); - struct.success = new HashMap(2*_map384.size); - for (int _i385 = 0; _i385 < _map384.size; ++_i385) + org.apache.thrift.protocol.TMap _map432 = new org.apache.thrift.protocol.TMap(org.apache.thrift.protocol.TType.STRING, org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); + struct.success = new HashMap(2*_map432.size); + for (int _i433 = 0; _i433 < _map432.size; ++_i433) { - String _key386; // required - Type _val387; // required - _key386 = iprot.readString(); - _val387 = new Type(); - _val387.read(iprot); - struct.success.put(_key386, _val387); + String _key434; // required + Type _val435; // required + _key434 = iprot.readString(); + _val435 = new Type(); + _val435.read(iprot); + struct.success.put(_key434, _val435); } } struct.setSuccessIsSet(true); @@ -19552,14 +20566,14 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list388 = iprot.readListBegin(); - struct.success = new ArrayList(_list388.size); - for (int _i389 = 0; _i389 < _list388.size; ++_i389) + org.apache.thrift.protocol.TList _list436 = iprot.readListBegin(); + struct.success = new ArrayList(_list436.size); + for (int _i437 = 0; _i437 < _list436.size; ++_i437) { - FieldSchema _elem390; // optional - _elem390 = new FieldSchema(); - _elem390.read(iprot); - struct.success.add(_elem390); + FieldSchema _elem438; // required + _elem438 = new FieldSchema(); + _elem438.read(iprot); + struct.success.add(_elem438); } iprot.readListEnd(); } @@ -19612,9 +20626,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 _iter391 : struct.success) + for (FieldSchema _iter439 : struct.success) { - _iter391.write(oprot); + _iter439.write(oprot); } oprot.writeListEnd(); } @@ -19669,9 +20683,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (FieldSchema _iter392 : struct.success) + for (FieldSchema _iter440 : struct.success) { - _iter392.write(oprot); + _iter440.write(oprot); } } } @@ -19692,14 +20706,14 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list393 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); - struct.success = new ArrayList(_list393.size); - for (int _i394 = 0; _i394 < _list393.size; ++_i394) + org.apache.thrift.protocol.TList _list441 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); + struct.success = new ArrayList(_list441.size); + for (int _i442 = 0; _i442 < _list441.size; ++_i442) { - FieldSchema _elem395; // optional - _elem395 = new FieldSchema(); - _elem395.read(iprot); - struct.success.add(_elem395); + FieldSchema _elem443; // required + _elem443 = new FieldSchema(); + _elem443.read(iprot); + struct.success.add(_elem443); } } struct.setSuccessIsSet(true); @@ -20744,14 +21758,14 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list396 = iprot.readListBegin(); - struct.success = new ArrayList(_list396.size); - for (int _i397 = 0; _i397 < _list396.size; ++_i397) + org.apache.thrift.protocol.TList _list444 = iprot.readListBegin(); + struct.success = new ArrayList(_list444.size); + for (int _i445 = 0; _i445 < _list444.size; ++_i445) { - FieldSchema _elem398; // optional - _elem398 = new FieldSchema(); - _elem398.read(iprot); - struct.success.add(_elem398); + FieldSchema _elem446; // required + _elem446 = new FieldSchema(); + _elem446.read(iprot); + struct.success.add(_elem446); } iprot.readListEnd(); } @@ -20804,9 +21818,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 _iter399 : struct.success) + for (FieldSchema _iter447 : struct.success) { - _iter399.write(oprot); + _iter447.write(oprot); } oprot.writeListEnd(); } @@ -20861,9 +21875,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (FieldSchema _iter400 : struct.success) + for (FieldSchema _iter448 : struct.success) { - _iter400.write(oprot); + _iter448.write(oprot); } } } @@ -20884,14 +21898,14 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list401 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); - struct.success = new ArrayList(_list401.size); - for (int _i402 = 0; _i402 < _list401.size; ++_i402) + org.apache.thrift.protocol.TList _list449 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); + struct.success = new ArrayList(_list449.size); + for (int _i450 = 0; _i450 < _list449.size; ++_i450) { - FieldSchema _elem403; // optional - _elem403 = new FieldSchema(); - _elem403.read(iprot); - struct.success.add(_elem403); + FieldSchema _elem451; // required + _elem451 = new FieldSchema(); + _elem451.read(iprot); + struct.success.add(_elem451); } } struct.setSuccessIsSet(true); @@ -26134,13 +27148,13 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list404 = iprot.readListBegin(); - struct.success = new ArrayList(_list404.size); - for (int _i405 = 0; _i405 < _list404.size; ++_i405) + org.apache.thrift.protocol.TList _list452 = iprot.readListBegin(); + struct.success = new ArrayList(_list452.size); + for (int _i453 = 0; _i453 < _list452.size; ++_i453) { - String _elem406; // optional - _elem406 = iprot.readString(); - struct.success.add(_elem406); + String _elem454; // required + _elem454 = iprot.readString(); + struct.success.add(_elem454); } iprot.readListEnd(); } @@ -26175,9 +27189,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 _iter407 : struct.success) + for (String _iter455 : struct.success) { - oprot.writeString(_iter407); + oprot.writeString(_iter455); } oprot.writeListEnd(); } @@ -26216,9 +27230,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (String _iter408 : struct.success) + for (String _iter456 : struct.success) { - oprot.writeString(_iter408); + oprot.writeString(_iter456); } } } @@ -26233,13 +27247,13 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list409 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.success = new ArrayList(_list409.size); - for (int _i410 = 0; _i410 < _list409.size; ++_i410) + org.apache.thrift.protocol.TList _list457 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.success = new ArrayList(_list457.size); + for (int _i458 = 0; _i458 < _list457.size; ++_i458) { - String _elem411; // optional - _elem411 = iprot.readString(); - struct.success.add(_elem411); + String _elem459; // required + _elem459 = iprot.readString(); + struct.success.add(_elem459); } } struct.setSuccessIsSet(true); @@ -27008,13 +28022,13 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list412 = iprot.readListBegin(); - struct.success = new ArrayList(_list412.size); - for (int _i413 = 0; _i413 < _list412.size; ++_i413) + org.apache.thrift.protocol.TList _list460 = iprot.readListBegin(); + struct.success = new ArrayList(_list460.size); + for (int _i461 = 0; _i461 < _list460.size; ++_i461) { - String _elem414; // optional - _elem414 = iprot.readString(); - struct.success.add(_elem414); + String _elem462; // required + _elem462 = iprot.readString(); + struct.success.add(_elem462); } iprot.readListEnd(); } @@ -27049,9 +28063,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 _iter415 : struct.success) + for (String _iter463 : struct.success) { - oprot.writeString(_iter415); + oprot.writeString(_iter463); } oprot.writeListEnd(); } @@ -27090,9 +28104,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (String _iter416 : struct.success) + for (String _iter464 : struct.success) { - oprot.writeString(_iter416); + oprot.writeString(_iter464); } } } @@ -27107,13 +28121,13 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(2); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list417 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.success = new ArrayList(_list417.size); - for (int _i418 = 0; _i418 < _list417.size; ++_i418) + org.apache.thrift.protocol.TList _list465 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.success = new ArrayList(_list465.size); + for (int _i466 = 0; _i466 < _list465.size; ++_i466) { - String _elem419; // optional - _elem419 = iprot.readString(); - struct.success.add(_elem419); + String _elem467; // required + _elem467 = iprot.readString(); + struct.success.add(_elem467); } } struct.setSuccessIsSet(true); @@ -28569,13 +29583,13 @@ public class ThriftHiveMetastore { case 2: // TBL_NAMES if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list420 = iprot.readListBegin(); - struct.tbl_names = new ArrayList(_list420.size); - for (int _i421 = 0; _i421 < _list420.size; ++_i421) + org.apache.thrift.protocol.TList _list468 = iprot.readListBegin(); + struct.tbl_names = new ArrayList(_list468.size); + for (int _i469 = 0; _i469 < _list468.size; ++_i469) { - String _elem422; // optional - _elem422 = iprot.readString(); - struct.tbl_names.add(_elem422); + String _elem470; // required + _elem470 = iprot.readString(); + struct.tbl_names.add(_elem470); } iprot.readListEnd(); } @@ -28606,9 +29620,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 _iter423 : struct.tbl_names) + for (String _iter471 : struct.tbl_names) { - oprot.writeString(_iter423); + oprot.writeString(_iter471); } oprot.writeListEnd(); } @@ -28645,9 +29659,9 @@ public class ThriftHiveMetastore { if (struct.isSetTbl_names()) { { oprot.writeI32(struct.tbl_names.size()); - for (String _iter424 : struct.tbl_names) + for (String _iter472 : struct.tbl_names) { - oprot.writeString(_iter424); + oprot.writeString(_iter472); } } } @@ -28663,13 +29677,13 @@ public class ThriftHiveMetastore { } if (incoming.get(1)) { { - org.apache.thrift.protocol.TList _list425 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.tbl_names = new ArrayList(_list425.size); - for (int _i426 = 0; _i426 < _list425.size; ++_i426) + org.apache.thrift.protocol.TList _list473 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.tbl_names = new ArrayList(_list473.size); + for (int _i474 = 0; _i474 < _list473.size; ++_i474) { - String _elem427; // optional - _elem427 = iprot.readString(); - struct.tbl_names.add(_elem427); + String _elem475; // required + _elem475 = iprot.readString(); + struct.tbl_names.add(_elem475); } } struct.setTbl_namesIsSet(true); @@ -29237,14 +30251,14 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list428 = iprot.readListBegin(); - struct.success = new ArrayList(_list428.size); - for (int _i429 = 0; _i429 < _list428.size; ++_i429) + org.apache.thrift.protocol.TList _list476 = iprot.readListBegin(); + struct.success = new ArrayList
(_list476.size); + for (int _i477 = 0; _i477 < _list476.size; ++_i477) { - Table _elem430; // optional - _elem430 = new Table(); - _elem430.read(iprot); - struct.success.add(_elem430); + Table _elem478; // required + _elem478 = new Table(); + _elem478.read(iprot); + struct.success.add(_elem478); } iprot.readListEnd(); } @@ -29297,9 +30311,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 _iter431 : struct.success) + for (Table _iter479 : struct.success) { - _iter431.write(oprot); + _iter479.write(oprot); } oprot.writeListEnd(); } @@ -29354,9 +30368,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (Table _iter432 : struct.success) + for (Table _iter480 : struct.success) { - _iter432.write(oprot); + _iter480.write(oprot); } } } @@ -29377,14 +30391,14 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list433 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); - struct.success = new ArrayList
(_list433.size); - for (int _i434 = 0; _i434 < _list433.size; ++_i434) + org.apache.thrift.protocol.TList _list481 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); + struct.success = new ArrayList
(_list481.size); + for (int _i482 = 0; _i482 < _list481.size; ++_i482) { - Table _elem435; // optional - _elem435 = new Table(); - _elem435.read(iprot); - struct.success.add(_elem435); + Table _elem483; // required + _elem483 = new Table(); + _elem483.read(iprot); + struct.success.add(_elem483); } } struct.setSuccessIsSet(true); @@ -30533,13 +31547,13 @@ public class ThriftHiveMetastore { case 0: // SUCCESS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list436 = iprot.readListBegin(); - struct.success = new ArrayList(_list436.size); - for (int _i437 = 0; _i437 < _list436.size; ++_i437) + org.apache.thrift.protocol.TList _list484 = iprot.readListBegin(); + struct.success = new ArrayList(_list484.size); + for (int _i485 = 0; _i485 < _list484.size; ++_i485) { - String _elem438; // optional - _elem438 = iprot.readString(); - struct.success.add(_elem438); + String _elem486; // required + _elem486 = iprot.readString(); + struct.success.add(_elem486); } iprot.readListEnd(); } @@ -30592,9 +31606,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 _iter439 : struct.success) + for (String _iter487 : struct.success) { - oprot.writeString(_iter439); + oprot.writeString(_iter487); } oprot.writeListEnd(); } @@ -30649,9 +31663,9 @@ public class ThriftHiveMetastore { if (struct.isSetSuccess()) { { oprot.writeI32(struct.success.size()); - for (String _iter440 : struct.success) + for (String _iter488 : struct.success) { - oprot.writeString(_iter440); + oprot.writeString(_iter488); } } } @@ -30672,13 +31686,13 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(4); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list441 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); - struct.success = new ArrayList(_list441.size); - for (int _i442 = 0; _i442 < _list441.size; ++_i442) + org.apache.thrift.protocol.TList _list489 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRING, iprot.readI32()); + struct.success = new ArrayList(_list489.size); + for (int _i490 = 0; _i490 < _list489.size; ++_i490) { - String _elem443; // optional - _elem443 = iprot.readString(); - struct.success.add(_elem443); + String _elem491; // required + _elem491 = iprot.readString(); + struct.success.add(_elem491); } } struct.setSuccessIsSet(true); @@ -35398,14 +36412,14 @@ public class ThriftHiveMetastore { case 1: // NEW_PARTS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list444 = iprot.readListBegin(); - struct.new_parts = new ArrayList(_list444.size); - for (int _i445 = 0; _i445 < _list444.size; ++_i445) + org.apache.thrift.protocol.TList _list492 = iprot.readListBegin(); + struct.new_parts = new ArrayList(_list492.size); + for (int _i493 = 0; _i493 < _list492.size; ++_i493) { - Partition _elem446; // optional - _elem446 = new Partition(); - _elem446.read(iprot); - struct.new_parts.add(_elem446); + Partition _elem494; // required + _elem494 = new Partition(); + _elem494.read(iprot); + struct.new_parts.add(_elem494); } iprot.readListEnd(); } @@ -35431,9 +36445,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 _iter447 : struct.new_parts) + for (Partition _iter495 : struct.new_parts) { - _iter447.write(oprot); + _iter495.write(oprot); } oprot.writeListEnd(); } @@ -35464,9 +36478,9 @@ public class ThriftHiveMetastore { if (struct.isSetNew_parts()) { { oprot.writeI32(struct.new_parts.size()); - for (Partition _iter448 : struct.new_parts) + for (Partition _iter496 : struct.new_parts) { - _iter448.write(oprot); + _iter496.write(oprot); } } } @@ -35478,14 +36492,14 @@ public class ThriftHiveMetastore { BitSet incoming = iprot.readBitSet(1); if (incoming.get(0)) { { - org.apache.thrift.protocol.TList _list449 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); - struct.new_parts = new ArrayList(_list449.size); - for (int _i450 = 0; _i450 < _list449.size; ++_i450) + org.apache.thrift.protocol.TList _list497 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32()); + struct.new_parts = new ArrayList(_list497.size); + for (int _i498 = 0; _i498 < _list497.size; ++_i498) { - Partition _elem451; // optional - _elem451 = new Partition(); - _elem451.read(iprot); - struct.new_parts.add(_elem451); + Partition _elem499; // required + _elem499 = new Partition(); + _elem499.read(iprot); + struct.new_parts.add(_elem499); } } struct.setNew_partsIsSet(true); @@ -36664,13 +37678,13 @@ public class ThriftHiveMetastore { case 3: // PART_VALS if (schemeField.type == org.apache.thrift.protocol.TType.LIST) { { - org.apache.thrift.protocol.TList _list452 = iprot.readListBegin(); - struct.part_vals = new ArrayList(_list452.size); - for (int _i453 = 0; _i453 < _list452.size; ++_i453) + org.apache.thrift.protocol.TList _list500 = iprot.readListBegin(); + struct.part_vals = new ArrayList(_list500.size); + for (int _i501 = 0; _i501 < _list500.size; ++_i501) { - String _elem454; // optional - _elem454 = iprot.readString(); - struct.part_vals.add(_elem454); + String _elem502; // required + _elem502 = iprot.readString(); [... 11813 lines stripped ...]