You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by se...@apache.org on 2018/07/18 18:52:44 UTC

[48/48] hive git commit: HIVE-19416 : merge master into branch (Sergey Shelukhin) 0718

HIVE-19416 : merge master into branch (Sergey Shelukhin) 0718


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

Branch: refs/heads/master-txnstats
Commit: 37a1907be4ecff19777a86f8b3d860861613af15
Parents: 1c9947f bac1d98
Author: sergey <se...@apache.org>
Authored: Wed Jul 18 11:51:35 2018 -0700
Committer: sergey <se...@apache.org>
Committed: Wed Jul 18 11:51:35 2018 -0700

----------------------------------------------------------------------
 .../org/apache/hadoop/hive/conf/HiveConf.java   |   32 +-
 .../apache/hadoop/hive/hbase/HBaseMetaHook.java |   56 +-
 .../src/test/queries/negative/cascade_dbdrop.q  |    4 +-
 .../generatehfiles_require_family_path.q        |    5 +-
 .../src/test/queries/negative/hbase_ddl.q       |    4 +-
 .../positive/drop_database_table_hooks.q        |   57 +
 .../test/queries/positive/external_table_ppd.q  |    5 +-
 .../test/queries/positive/hbase_binary_binary.q |    5 +-
 .../queries/positive/hbase_binary_map_queries.q |   13 +-
 .../positive/hbase_binary_map_queries_prefix.q  |    9 +-
 .../positive/hbase_binary_storage_queries.q     |   12 +-
 .../test/queries/positive/hbase_custom_key.q    |    5 +-
 .../test/queries/positive/hbase_custom_key2.q   |    5 +-
 .../test/queries/positive/hbase_custom_key3.q   |    5 +-
 .../src/test/queries/positive/hbase_ddl.q       |    4 +-
 .../queries/positive/hbase_decimal_decimal.q    |    5 +-
 .../test/queries/positive/hbase_handler_bulk.q  |   11 +-
 .../src/test/queries/positive/hbase_joins.q     |   25 +-
 .../queries/positive/hbase_null_first_col.q     |    5 +-
 .../src/test/queries/positive/hbase_ppd_join.q  |    8 +-
 .../test/queries/positive/hbase_ppd_key_range.q |    5 +-
 .../src/test/queries/positive/hbase_pushdown.q  |    5 +-
 .../src/test/queries/positive/hbase_queries.q   |   54 +-
 .../test/queries/positive/hbase_scan_params.q   |    5 +-
 .../hbase_single_sourced_multi_insert.q         |    5 +-
 .../src/test/queries/positive/hbase_timestamp.q |   20 +-
 .../queries/positive/hbase_timestamp_format.q   |    4 +-
 .../src/test/queries/positive/hbase_viewjoins.q |   10 +-
 .../src/test/queries/positive/hbasestats.q      |    5 +-
 .../src/test/queries/positive/ppd_key_ranges.q  |    5 +-
 .../test/results/negative/cascade_dbdrop.q.out  |    8 +-
 .../generatehfiles_require_family_path.q.out    |    6 +-
 .../src/test/results/negative/hbase_ddl.q.out   |    8 +-
 .../positive/drop_database_table_hooks.q.out    |  258 ++
 .../results/positive/external_table_ppd.q.out   |   14 +-
 .../results/positive/hbase_binary_binary.q.out  |    6 +-
 .../positive/hbase_binary_map_queries.q.out     |   22 +-
 .../hbase_binary_map_queries_prefix.q.out       |   14 +-
 .../positive/hbase_binary_storage_queries.q.out |   28 +-
 .../results/positive/hbase_custom_key.q.out     |    6 +-
 .../results/positive/hbase_custom_key2.q.out    |    6 +-
 .../results/positive/hbase_custom_key3.q.out    |    6 +-
 .../src/test/results/positive/hbase_ddl.q.out   |   16 +-
 .../positive/hbase_decimal_decimal.q.out        |  Bin 1758 -> 1872 bytes
 .../results/positive/hbase_handler_bulk.q.out   |   16 +-
 .../src/test/results/positive/hbase_joins.q.out |   30 +-
 .../results/positive/hbase_null_first_col.q.out |    6 +-
 .../test/results/positive/hbase_ppd_join.q.out  |   12 +-
 .../results/positive/hbase_ppd_key_range.q.out  |    6 +-
 .../test/results/positive/hbase_pushdown.q.out  |    6 +-
 .../test/results/positive/hbase_queries.q.out   |   68 +-
 .../results/positive/hbase_scan_params.q.out    |    6 +-
 .../hbase_single_sourced_multi_insert.q.out     |    6 +-
 .../test/results/positive/hbase_timestamp.q.out |   24 +-
 .../positive/hbase_timestamp_format.q.out       |    8 +-
 .../test/results/positive/hbase_viewjoins.q.out |   20 +-
 .../src/test/results/positive/hbasestats.q.out  |   26 +-
 .../test/results/positive/ppd_key_ranges.q.out  |    6 +-
 .../apache/hive/jdbc/TestRestrictedList.java    |    2 +-
 .../test/resources/testconfiguration.properties |    1 +
 .../hive/llap/io/api/impl/LlapRecordReader.java |   60 +-
 .../UDAFTemplates/VectorUDAFAvg.txt             |  108 +-
 .../UDAFTemplates/VectorUDAFAvgDecimal.txt      |   83 +-
 .../VectorUDAFAvgDecimal64ToDecimal.txt         |  110 +-
 .../UDAFTemplates/VectorUDAFAvgDecimalMerge.txt |   35 +-
 .../UDAFTemplates/VectorUDAFAvgMerge.txt        |   35 +-
 .../UDAFTemplates/VectorUDAFAvgTimestamp.txt    |  136 +-
 .../UDAFTemplates/VectorUDAFMinMax.txt          |   38 +-
 .../UDAFTemplates/VectorUDAFMinMaxDecimal.txt   |   98 +-
 .../VectorUDAFMinMaxIntervalDayTime.txt         |  102 +-
 .../UDAFTemplates/VectorUDAFMinMaxString.txt    |   50 +-
 .../UDAFTemplates/VectorUDAFMinMaxTimestamp.txt |  104 +-
 .../UDAFTemplates/VectorUDAFSum.txt             |   34 +-
 .../UDAFTemplates/VectorUDAFVar.txt             |    9 +-
 .../UDAFTemplates/VectorUDAFVarDecimal.txt      |   19 +-
 .../UDAFTemplates/VectorUDAFVarMerge.txt        |   60 +-
 .../UDAFTemplates/VectorUDAFVarTimestamp.txt    |   19 +-
 .../hive/ql/exec/MaterializedViewTask.java      |    2 -
 .../hadoop/hive/ql/exec/repl/ReplDumpTask.java  |   52 +-
 .../apache/hadoop/hive/ql/exec/tez/TezTask.java |    4 +
 .../ql/exec/vector/VectorAggregationDesc.java   |   19 +-
 .../aggregates/VectorAggregateExpression.java   |    2 +-
 .../aggregates/VectorUDAFCountMerge.java        |   34 +-
 .../aggregates/VectorUDAFSumDecimal.java        |   37 +-
 .../aggregates/VectorUDAFSumDecimal64.java      |   34 +-
 .../VectorUDAFSumDecimal64ToDecimal.java        |   34 +-
 .../aggregates/VectorUDAFSumTimestamp.java      |   34 +-
 .../hadoop/hive/ql/io/orc/OrcRecordUpdater.java |    1 -
 .../hadoop/hive/ql/log/LogDivertAppender.java   |    6 +-
 .../apache/hadoop/hive/ql/metadata/Hive.java    |  122 +-
 .../hadoop/hive/ql/metadata/TableIterable.java  |  104 -
 .../hive/ql/optimizer/physical/Vectorizer.java  |   54 +-
 .../apache/hadoop/hive/ql/parse/ASTNode.java    |   31 +-
 .../hadoop/hive/ql/parse/ASTNodeOrigin.java     |    4 +-
 .../hadoop/hive/ql/parse/CalcitePlanner.java    |   64 +-
 .../hive/ql/parse/ImmutableCommonToken.java     |  107 +
 .../hadoop/hive/ql/parse/ParseDriver.java       |   16 +-
 .../org/apache/hadoop/hive/ql/parse/QBExpr.java |    5 +-
 .../hadoop/hive/ql/parse/QBParseInfo.java       |    5 +-
 .../hadoop/hive/ql/parse/SemanticAnalyzer.java  |   21 +-
 .../hadoop/hive/ql/parse/SubQueryUtils.java     |   11 +-
 .../hadoop/hive/ql/parse/TezCompiler.java       |  444 ++-
 .../hadoop/hive/ql/parse/repl/dump/Utils.java   |    4 +-
 .../hive/ql/ppd/ExprWalkerProcFactory.java      |   30 +-
 .../hive/ql/ppd/SyntheticJoinPredicate.java     |  174 +-
 .../hive/ql/udf/generic/GenericUDAFAverage.java |   21 +
 .../ql/udf/generic/GenericUDAFVariance.java     |   19 +-
 .../hive/ql/exec/repl/ReplDumpTaskTest.java     |  126 +
 .../exec/vector/TestVectorGroupByOperator.java  |   52 +-
 .../ql/exec/vector/VectorRandomBatchSource.java |   51 +-
 .../ql/exec/vector/VectorRandomRowSource.java   |  253 +-
 .../vector/aggregation/AggregationBase.java     |  473 +++
 .../aggregation/TestVectorAggregation.java      |  664 ++++
 .../expressions/TestVectorDateAddSub.java       |    2 +
 .../vector/expressions/TestVectorDateDiff.java  |    2 +
 .../expressions/TestVectorIfStatement.java      |    4 +
 .../vector/expressions/TestVectorNegative.java  |    5 +
 .../expressions/TestVectorStringConcat.java     |    4 +
 .../expressions/TestVectorStringUnary.java      |    2 +
 .../vector/expressions/TestVectorSubStr.java    |    2 +
 .../expressions/TestVectorTimestampExtract.java |    4 +
 .../hive/ql/metadata/TestTableIterable.java     |   67 -
 .../ql/optimizer/physical/TestVectorizer.java   |    5 +-
 .../dynamic_semijoin_reduction_sw2.q            |   59 +
 ...terialized_view_create_rewrite_time_window.q |    4 +-
 .../clientpositive/ppd_deterministic_expr.q     |  143 +
 .../test/queries/clientpositive/ppd_udf_col.q   |   48 +
 .../clientpositive/druid/druidmini_mv.q.out     |   85 +-
 .../clientpositive/llap/check_constraint.q.out  |   17 +-
 .../llap/dynamic_semijoin_reduction_sw2.q.out   |  450 +++
 .../llap/enforce_constraint_notnull.q.out       |   17 +-
 .../clientpositive/llap/explainuser_1.q.out     |   12 +-
 .../results/clientpositive/llap/lineage3.q.out  |    2 +-
 .../materialized_view_create_rewrite_5.q.out    |    4 +-
 ...alized_view_create_rewrite_time_window.q.out |   16 +-
 .../llap/materialized_view_rewrite_empty.q.out  |    4 +-
 .../llap/orc_ppd_schema_evol_3a.q.out           |   52 +-
 .../clientpositive/llap/subquery_in.q.out       |   22 +-
 .../clientpositive/llap/subquery_notin.q.out    |   68 +-
 .../llap/tez_fixed_bucket_pruning.q.out         |    8 +-
 .../clientpositive/masking_disablecbo_2.q.out   |  219 +-
 .../clientpositive/perf/tez/query1.q.out        |   76 +-
 .../clientpositive/perf/tez/query16.q.out       |  118 +-
 .../clientpositive/perf/tez/query17.q.out       |  197 +-
 .../clientpositive/perf/tez/query18.q.out       |  124 +-
 .../clientpositive/perf/tez/query2.q.out        |  116 +-
 .../clientpositive/perf/tez/query23.q.out       |  444 +--
 .../clientpositive/perf/tez/query24.q.out       |  252 +-
 .../clientpositive/perf/tez/query25.q.out       |  188 +-
 .../clientpositive/perf/tez/query29.q.out       |  148 +-
 .../clientpositive/perf/tez/query31.q.out       |  322 +-
 .../clientpositive/perf/tez/query32.q.out       |  140 +-
 .../clientpositive/perf/tez/query39.q.out       |   94 +-
 .../clientpositive/perf/tez/query40.q.out       |   92 +-
 .../clientpositive/perf/tez/query54.q.out       |  246 +-
 .../clientpositive/perf/tez/query59.q.out       |  134 +-
 .../clientpositive/perf/tez/query64.q.out       |  760 ++---
 .../clientpositive/perf/tez/query69.q.out       |  144 +-
 .../clientpositive/perf/tez/query72.q.out       |  178 +-
 .../clientpositive/perf/tez/query77.q.out       |  248 +-
 .../clientpositive/perf/tez/query78.q.out       |  136 +-
 .../clientpositive/perf/tez/query8.q.out        |  116 +-
 .../clientpositive/perf/tez/query80.q.out       |  336 +-
 .../clientpositive/perf/tez/query91.q.out       |   74 +-
 .../clientpositive/perf/tez/query92.q.out       |  174 +-
 .../clientpositive/perf/tez/query94.q.out       |  118 +-
 .../clientpositive/perf/tez/query95.q.out       |  241 +-
 .../clientpositive/ppd_deterministic_expr.q.out |  553 ++++
 .../results/clientpositive/ppd_udf_col.q.out    |  409 +++
 .../spark_dynamic_partition_pruning_3.q.out     |    3 +-
 .../results/clientpositive/union_offcbo.q.out   |   34 +-
 .../cli/operation/GetColumnsOperation.java      |    2 +-
 .../apache/hive/service/server/HiveServer2.java |   35 +-
 .../metastore/api/AlterPartitionsRequest.java   |   36 +-
 .../hive/metastore/api/CreationMetadata.java    |  111 +-
 .../metastore/api/FindSchemasByColsResp.java    |   36 +-
 .../hive/metastore/api/Materialization.java     |  409 +--
 .../hive/metastore/api/SchemaVersion.java       |   36 +-
 .../hive/metastore/api/ThriftHiveMetastore.java | 2858 +++++++++---------
 .../hive/metastore/api/WMFullResourcePlan.java  |  144 +-
 .../api/WMGetAllResourcePlanResponse.java       |   36 +-
 .../WMGetTriggersForResourePlanResponse.java    |   36 +-
 .../api/WMValidateResourcePlanResponse.java     |   64 +-
 .../gen-php/metastore/ThriftHiveMetastore.php   | 1510 +++++----
 .../src/gen/thrift/gen-php/metastore/Types.php  |  344 +--
 .../hive_metastore/ThriftHiveMetastore-remote   |    4 +-
 .../hive_metastore/ThriftHiveMetastore.py       | 1015 +++----
 .../gen/thrift/gen-py/hive_metastore/ttypes.py  |  222 +-
 .../gen/thrift/gen-rb/hive_metastore_types.rb   |   16 +-
 .../gen/thrift/gen-rb/thrift_hive_metastore.rb  |   20 +-
 .../hadoop/hive/metastore/HiveMetaStore.java    |   11 +-
 .../hive/metastore/HiveMetaStoreClient.java     |  124 +-
 .../hadoop/hive/metastore/IMetaStoreClient.java |    2 +-
 .../MaterializationsCacheCleanerTask.java       |   63 -
 .../MaterializationsInvalidationCache.java      |  543 ----
 .../MaterializationsRebuildLockCleanerTask.java |   30 +-
 .../hadoop/hive/metastore/ObjectStore.java      |   20 +-
 .../hadoop/hive/metastore/TableIterable.java    |  115 +
 .../hive/metastore/conf/MetastoreConf.java      |    6 +-
 .../hive/metastore/model/MCreationMetadata.java |   16 +-
 .../hadoop/hive/metastore/txn/TxnDbUtil.java    |   13 +-
 .../hadoop/hive/metastore/txn/TxnHandler.java   |  309 +-
 .../hadoop/hive/metastore/txn/TxnStore.java     |   37 +-
 .../main/sql/derby/hive-schema-3.1.0.derby.sql  |   14 +-
 .../main/sql/derby/hive-schema-4.0.0.derby.sql  |   14 +-
 .../sql/derby/upgrade-3.0.0-to-3.1.0.derby.sql  |   19 +
 .../main/sql/mssql/hive-schema-3.1.0.mssql.sql  |   17 +-
 .../main/sql/mssql/hive-schema-4.0.0.mssql.sql  |   18 +-
 .../sql/mssql/upgrade-3.0.0-to-3.1.0.mssql.sql  |   19 +
 .../main/sql/mysql/hive-schema-3.1.0.mysql.sql  |   12 +-
 .../main/sql/mysql/hive-schema-4.0.0.mysql.sql  |   12 +-
 .../sql/mysql/upgrade-3.0.0-to-3.1.0.mysql.sql  |   20 +
 .../sql/oracle/hive-schema-3.1.0.oracle.sql     |   14 +-
 .../sql/oracle/hive-schema-4.0.0.oracle.sql     |   14 +-
 .../oracle/upgrade-3.0.0-to-3.1.0.oracle.sql    |   19 +
 .../sql/postgres/hive-schema-3.1.0.postgres.sql |   14 +-
 .../sql/postgres/hive-schema-4.0.0.postgres.sql |   26 +-
 .../upgrade-3.0.0-to-3.1.0.postgres.sql         |   19 +
 .../src/main/thrift/hive_metastore.thrift       |    8 +-
 .../HiveMetaStoreClientPreCatalog.java          |    7 +-
 ...stMetaStoreMaterializationsCacheCleaner.java |  328 --
 .../hive/metastore/TestTableIterable.java       |   76 +
 .../TestTablesCreateDropAlterTruncate.java      |    1 +
 .../ql/exec/vector/TimestampColumnVector.java   |    2 +-
 .../ql/exec/vector/TestStructColumnVector.java  |    1 +
 .../apache/hive/streaming/TestStreaming.java    |   21 +-
 226 files changed, 12148 insertions(+), 9560 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/ql/src/java/org/apache/hadoop/hive/ql/metadata/Hive.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/ql/src/java/org/apache/hadoop/hive/ql/parse/SemanticAnalyzer.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/ql/src/test/results/clientpositive/llap/enforce_constraint_notnull.q.out
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/ql/src/test/results/clientpositive/llap/materialized_view_create_rewrite_5.q.out
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/ql/src/test/results/clientpositive/llap/materialized_view_create_rewrite_time_window.q.out
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlterPartitionsRequest.java
----------------------------------------------------------------------
diff --cc standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlterPartitionsRequest.java
index 9d0e014,0000000..45832a4
mode 100644,000000..100644
--- a/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlterPartitionsRequest.java
+++ b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/AlterPartitionsRequest.java
@@@ -1,1178 -1,0 +1,1178 @@@
 +/**
 + * Autogenerated by Thrift Compiler (0.9.3)
 + *
 + * DO NOT EDIT UNLESS YOU ARE SURE THAT YOU KNOW WHAT YOU ARE DOING
 + *  @generated
 + */
 +package org.apache.hadoop.hive.metastore.api;
 +
 +import org.apache.thrift.scheme.IScheme;
 +import org.apache.thrift.scheme.SchemeFactory;
 +import org.apache.thrift.scheme.StandardScheme;
 +
 +import org.apache.thrift.scheme.TupleScheme;
 +import org.apache.thrift.protocol.TTupleProtocol;
 +import org.apache.thrift.protocol.TProtocolException;
 +import org.apache.thrift.EncodingUtils;
 +import org.apache.thrift.TException;
 +import org.apache.thrift.async.AsyncMethodCallback;
 +import org.apache.thrift.server.AbstractNonblockingServer.*;
 +import java.util.List;
 +import java.util.ArrayList;
 +import java.util.Map;
 +import java.util.HashMap;
 +import java.util.EnumMap;
 +import java.util.Set;
 +import java.util.HashSet;
 +import java.util.EnumSet;
 +import java.util.Collections;
 +import java.util.BitSet;
 +import java.nio.ByteBuffer;
 +import java.util.Arrays;
 +import javax.annotation.Generated;
 +import org.slf4j.Logger;
 +import org.slf4j.LoggerFactory;
 +
 +@SuppressWarnings({"cast", "rawtypes", "serial", "unchecked"})
 +@Generated(value = "Autogenerated by Thrift Compiler (0.9.3)")
 +@org.apache.hadoop.classification.InterfaceAudience.Public @org.apache.hadoop.classification.InterfaceStability.Stable public class AlterPartitionsRequest implements org.apache.thrift.TBase<AlterPartitionsRequest, AlterPartitionsRequest._Fields>, java.io.Serializable, Cloneable, Comparable<AlterPartitionsRequest> {
 +  private static final org.apache.thrift.protocol.TStruct STRUCT_DESC = new org.apache.thrift.protocol.TStruct("AlterPartitionsRequest");
 +
 +  private static final org.apache.thrift.protocol.TField CAT_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("catName", org.apache.thrift.protocol.TType.STRING, (short)1);
 +  private static final org.apache.thrift.protocol.TField DB_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("dbName", org.apache.thrift.protocol.TType.STRING, (short)2);
 +  private static final org.apache.thrift.protocol.TField TABLE_NAME_FIELD_DESC = new org.apache.thrift.protocol.TField("tableName", org.apache.thrift.protocol.TType.STRING, (short)3);
 +  private static final org.apache.thrift.protocol.TField PARTITIONS_FIELD_DESC = new org.apache.thrift.protocol.TField("partitions", org.apache.thrift.protocol.TType.LIST, (short)4);
 +  private static final org.apache.thrift.protocol.TField ENVIRONMENT_CONTEXT_FIELD_DESC = new org.apache.thrift.protocol.TField("environmentContext", org.apache.thrift.protocol.TType.STRUCT, (short)5);
 +  private static final org.apache.thrift.protocol.TField TXN_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("txnId", org.apache.thrift.protocol.TType.I64, (short)6);
 +  private static final org.apache.thrift.protocol.TField WRITE_ID_FIELD_DESC = new org.apache.thrift.protocol.TField("writeId", org.apache.thrift.protocol.TType.I64, (short)7);
 +  private static final org.apache.thrift.protocol.TField VALID_WRITE_ID_LIST_FIELD_DESC = new org.apache.thrift.protocol.TField("validWriteIdList", org.apache.thrift.protocol.TType.STRING, (short)8);
 +
 +  private static final Map<Class<? extends IScheme>, SchemeFactory> schemes = new HashMap<Class<? extends IScheme>, SchemeFactory>();
 +  static {
 +    schemes.put(StandardScheme.class, new AlterPartitionsRequestStandardSchemeFactory());
 +    schemes.put(TupleScheme.class, new AlterPartitionsRequestTupleSchemeFactory());
 +  }
 +
 +  private String catName; // optional
 +  private String dbName; // required
 +  private String tableName; // required
 +  private List<Partition> partitions; // required
 +  private EnvironmentContext environmentContext; // optional
 +  private long txnId; // optional
 +  private long writeId; // optional
 +  private String validWriteIdList; // optional
 +
 +  /** The set of fields this struct contains, along with convenience methods for finding and manipulating them. */
 +  public enum _Fields implements org.apache.thrift.TFieldIdEnum {
 +    CAT_NAME((short)1, "catName"),
 +    DB_NAME((short)2, "dbName"),
 +    TABLE_NAME((short)3, "tableName"),
 +    PARTITIONS((short)4, "partitions"),
 +    ENVIRONMENT_CONTEXT((short)5, "environmentContext"),
 +    TXN_ID((short)6, "txnId"),
 +    WRITE_ID((short)7, "writeId"),
 +    VALID_WRITE_ID_LIST((short)8, "validWriteIdList");
 +
 +    private static final Map<String, _Fields> byName = new HashMap<String, _Fields>();
 +
 +    static {
 +      for (_Fields field : EnumSet.allOf(_Fields.class)) {
 +        byName.put(field.getFieldName(), field);
 +      }
 +    }
 +
 +    /**
 +     * Find the _Fields constant that matches fieldId, or null if its not found.
 +     */
 +    public static _Fields findByThriftId(int fieldId) {
 +      switch(fieldId) {
 +        case 1: // CAT_NAME
 +          return CAT_NAME;
 +        case 2: // DB_NAME
 +          return DB_NAME;
 +        case 3: // TABLE_NAME
 +          return TABLE_NAME;
 +        case 4: // PARTITIONS
 +          return PARTITIONS;
 +        case 5: // ENVIRONMENT_CONTEXT
 +          return ENVIRONMENT_CONTEXT;
 +        case 6: // TXN_ID
 +          return TXN_ID;
 +        case 7: // WRITE_ID
 +          return WRITE_ID;
 +        case 8: // VALID_WRITE_ID_LIST
 +          return VALID_WRITE_ID_LIST;
 +        default:
 +          return null;
 +      }
 +    }
 +
 +    /**
 +     * Find the _Fields constant that matches fieldId, throwing an exception
 +     * if it is not found.
 +     */
 +    public static _Fields findByThriftIdOrThrow(int fieldId) {
 +      _Fields fields = findByThriftId(fieldId);
 +      if (fields == null) throw new IllegalArgumentException("Field " + fieldId + " doesn't exist!");
 +      return fields;
 +    }
 +
 +    /**
 +     * Find the _Fields constant that matches name, or null if its not found.
 +     */
 +    public static _Fields findByName(String name) {
 +      return byName.get(name);
 +    }
 +
 +    private final short _thriftId;
 +    private final String _fieldName;
 +
 +    _Fields(short thriftId, String fieldName) {
 +      _thriftId = thriftId;
 +      _fieldName = fieldName;
 +    }
 +
 +    public short getThriftFieldId() {
 +      return _thriftId;
 +    }
 +
 +    public String getFieldName() {
 +      return _fieldName;
 +    }
 +  }
 +
 +  // isset id assignments
 +  private static final int __TXNID_ISSET_ID = 0;
 +  private static final int __WRITEID_ISSET_ID = 1;
 +  private byte __isset_bitfield = 0;
 +  private static final _Fields optionals[] = {_Fields.CAT_NAME,_Fields.ENVIRONMENT_CONTEXT,_Fields.TXN_ID,_Fields.WRITE_ID,_Fields.VALID_WRITE_ID_LIST};
 +  public static final Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> metaDataMap;
 +  static {
 +    Map<_Fields, org.apache.thrift.meta_data.FieldMetaData> tmpMap = new EnumMap<_Fields, org.apache.thrift.meta_data.FieldMetaData>(_Fields.class);
 +    tmpMap.put(_Fields.CAT_NAME, new org.apache.thrift.meta_data.FieldMetaData("catName", org.apache.thrift.TFieldRequirementType.OPTIONAL, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
 +    tmpMap.put(_Fields.DB_NAME, new org.apache.thrift.meta_data.FieldMetaData("dbName", org.apache.thrift.TFieldRequirementType.REQUIRED, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
 +    tmpMap.put(_Fields.TABLE_NAME, new org.apache.thrift.meta_data.FieldMetaData("tableName", org.apache.thrift.TFieldRequirementType.REQUIRED, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
 +    tmpMap.put(_Fields.PARTITIONS, new org.apache.thrift.meta_data.FieldMetaData("partitions", org.apache.thrift.TFieldRequirementType.REQUIRED, 
 +        new org.apache.thrift.meta_data.ListMetaData(org.apache.thrift.protocol.TType.LIST, 
 +            new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, Partition.class))));
 +    tmpMap.put(_Fields.ENVIRONMENT_CONTEXT, new org.apache.thrift.meta_data.FieldMetaData("environmentContext", org.apache.thrift.TFieldRequirementType.OPTIONAL, 
 +        new org.apache.thrift.meta_data.StructMetaData(org.apache.thrift.protocol.TType.STRUCT, EnvironmentContext.class)));
 +    tmpMap.put(_Fields.TXN_ID, new org.apache.thrift.meta_data.FieldMetaData("txnId", org.apache.thrift.TFieldRequirementType.OPTIONAL, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64)));
 +    tmpMap.put(_Fields.WRITE_ID, new org.apache.thrift.meta_data.FieldMetaData("writeId", org.apache.thrift.TFieldRequirementType.OPTIONAL, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.I64)));
 +    tmpMap.put(_Fields.VALID_WRITE_ID_LIST, new org.apache.thrift.meta_data.FieldMetaData("validWriteIdList", org.apache.thrift.TFieldRequirementType.OPTIONAL, 
 +        new org.apache.thrift.meta_data.FieldValueMetaData(org.apache.thrift.protocol.TType.STRING)));
 +    metaDataMap = Collections.unmodifiableMap(tmpMap);
 +    org.apache.thrift.meta_data.FieldMetaData.addStructMetaDataMap(AlterPartitionsRequest.class, metaDataMap);
 +  }
 +
 +  public AlterPartitionsRequest() {
 +    this.txnId = -1L;
 +
 +    this.writeId = -1L;
 +
 +  }
 +
 +  public AlterPartitionsRequest(
 +    String dbName,
 +    String tableName,
 +    List<Partition> partitions)
 +  {
 +    this();
 +    this.dbName = dbName;
 +    this.tableName = tableName;
 +    this.partitions = partitions;
 +  }
 +
 +  /**
 +   * Performs a deep copy on <i>other</i>.
 +   */
 +  public AlterPartitionsRequest(AlterPartitionsRequest other) {
 +    __isset_bitfield = other.__isset_bitfield;
 +    if (other.isSetCatName()) {
 +      this.catName = other.catName;
 +    }
 +    if (other.isSetDbName()) {
 +      this.dbName = other.dbName;
 +    }
 +    if (other.isSetTableName()) {
 +      this.tableName = other.tableName;
 +    }
 +    if (other.isSetPartitions()) {
 +      List<Partition> __this__partitions = new ArrayList<Partition>(other.partitions.size());
 +      for (Partition other_element : other.partitions) {
 +        __this__partitions.add(new Partition(other_element));
 +      }
 +      this.partitions = __this__partitions;
 +    }
 +    if (other.isSetEnvironmentContext()) {
 +      this.environmentContext = new EnvironmentContext(other.environmentContext);
 +    }
 +    this.txnId = other.txnId;
 +    this.writeId = other.writeId;
 +    if (other.isSetValidWriteIdList()) {
 +      this.validWriteIdList = other.validWriteIdList;
 +    }
 +  }
 +
 +  public AlterPartitionsRequest deepCopy() {
 +    return new AlterPartitionsRequest(this);
 +  }
 +
 +  @Override
 +  public void clear() {
 +    this.catName = null;
 +    this.dbName = null;
 +    this.tableName = null;
 +    this.partitions = null;
 +    this.environmentContext = null;
 +    this.txnId = -1L;
 +
 +    this.writeId = -1L;
 +
 +    this.validWriteIdList = null;
 +  }
 +
 +  public String getCatName() {
 +    return this.catName;
 +  }
 +
 +  public void setCatName(String catName) {
 +    this.catName = catName;
 +  }
 +
 +  public void unsetCatName() {
 +    this.catName = null;
 +  }
 +
 +  /** Returns true if field catName is set (has been assigned a value) and false otherwise */
 +  public boolean isSetCatName() {
 +    return this.catName != null;
 +  }
 +
 +  public void setCatNameIsSet(boolean value) {
 +    if (!value) {
 +      this.catName = null;
 +    }
 +  }
 +
 +  public String getDbName() {
 +    return this.dbName;
 +  }
 +
 +  public void setDbName(String dbName) {
 +    this.dbName = dbName;
 +  }
 +
 +  public void unsetDbName() {
 +    this.dbName = null;
 +  }
 +
 +  /** Returns true if field dbName is set (has been assigned a value) and false otherwise */
 +  public boolean isSetDbName() {
 +    return this.dbName != null;
 +  }
 +
 +  public void setDbNameIsSet(boolean value) {
 +    if (!value) {
 +      this.dbName = null;
 +    }
 +  }
 +
 +  public String getTableName() {
 +    return this.tableName;
 +  }
 +
 +  public void setTableName(String tableName) {
 +    this.tableName = tableName;
 +  }
 +
 +  public void unsetTableName() {
 +    this.tableName = null;
 +  }
 +
 +  /** Returns true if field tableName is set (has been assigned a value) and false otherwise */
 +  public boolean isSetTableName() {
 +    return this.tableName != null;
 +  }
 +
 +  public void setTableNameIsSet(boolean value) {
 +    if (!value) {
 +      this.tableName = null;
 +    }
 +  }
 +
 +  public int getPartitionsSize() {
 +    return (this.partitions == null) ? 0 : this.partitions.size();
 +  }
 +
 +  public java.util.Iterator<Partition> getPartitionsIterator() {
 +    return (this.partitions == null) ? null : this.partitions.iterator();
 +  }
 +
 +  public void addToPartitions(Partition elem) {
 +    if (this.partitions == null) {
 +      this.partitions = new ArrayList<Partition>();
 +    }
 +    this.partitions.add(elem);
 +  }
 +
 +  public List<Partition> getPartitions() {
 +    return this.partitions;
 +  }
 +
 +  public void setPartitions(List<Partition> partitions) {
 +    this.partitions = partitions;
 +  }
 +
 +  public void unsetPartitions() {
 +    this.partitions = null;
 +  }
 +
 +  /** Returns true if field partitions is set (has been assigned a value) and false otherwise */
 +  public boolean isSetPartitions() {
 +    return this.partitions != null;
 +  }
 +
 +  public void setPartitionsIsSet(boolean value) {
 +    if (!value) {
 +      this.partitions = null;
 +    }
 +  }
 +
 +  public EnvironmentContext getEnvironmentContext() {
 +    return this.environmentContext;
 +  }
 +
 +  public void setEnvironmentContext(EnvironmentContext environmentContext) {
 +    this.environmentContext = environmentContext;
 +  }
 +
 +  public void unsetEnvironmentContext() {
 +    this.environmentContext = null;
 +  }
 +
 +  /** Returns true if field environmentContext is set (has been assigned a value) and false otherwise */
 +  public boolean isSetEnvironmentContext() {
 +    return this.environmentContext != null;
 +  }
 +
 +  public void setEnvironmentContextIsSet(boolean value) {
 +    if (!value) {
 +      this.environmentContext = null;
 +    }
 +  }
 +
 +  public long getTxnId() {
 +    return this.txnId;
 +  }
 +
 +  public void setTxnId(long txnId) {
 +    this.txnId = txnId;
 +    setTxnIdIsSet(true);
 +  }
 +
 +  public void unsetTxnId() {
 +    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __TXNID_ISSET_ID);
 +  }
 +
 +  /** Returns true if field txnId is set (has been assigned a value) and false otherwise */
 +  public boolean isSetTxnId() {
 +    return EncodingUtils.testBit(__isset_bitfield, __TXNID_ISSET_ID);
 +  }
 +
 +  public void setTxnIdIsSet(boolean value) {
 +    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __TXNID_ISSET_ID, value);
 +  }
 +
 +  public long getWriteId() {
 +    return this.writeId;
 +  }
 +
 +  public void setWriteId(long writeId) {
 +    this.writeId = writeId;
 +    setWriteIdIsSet(true);
 +  }
 +
 +  public void unsetWriteId() {
 +    __isset_bitfield = EncodingUtils.clearBit(__isset_bitfield, __WRITEID_ISSET_ID);
 +  }
 +
 +  /** Returns true if field writeId is set (has been assigned a value) and false otherwise */
 +  public boolean isSetWriteId() {
 +    return EncodingUtils.testBit(__isset_bitfield, __WRITEID_ISSET_ID);
 +  }
 +
 +  public void setWriteIdIsSet(boolean value) {
 +    __isset_bitfield = EncodingUtils.setBit(__isset_bitfield, __WRITEID_ISSET_ID, value);
 +  }
 +
 +  public String getValidWriteIdList() {
 +    return this.validWriteIdList;
 +  }
 +
 +  public void setValidWriteIdList(String validWriteIdList) {
 +    this.validWriteIdList = validWriteIdList;
 +  }
 +
 +  public void unsetValidWriteIdList() {
 +    this.validWriteIdList = null;
 +  }
 +
 +  /** Returns true if field validWriteIdList is set (has been assigned a value) and false otherwise */
 +  public boolean isSetValidWriteIdList() {
 +    return this.validWriteIdList != null;
 +  }
 +
 +  public void setValidWriteIdListIsSet(boolean value) {
 +    if (!value) {
 +      this.validWriteIdList = null;
 +    }
 +  }
 +
 +  public void setFieldValue(_Fields field, Object value) {
 +    switch (field) {
 +    case CAT_NAME:
 +      if (value == null) {
 +        unsetCatName();
 +      } else {
 +        setCatName((String)value);
 +      }
 +      break;
 +
 +    case DB_NAME:
 +      if (value == null) {
 +        unsetDbName();
 +      } else {
 +        setDbName((String)value);
 +      }
 +      break;
 +
 +    case TABLE_NAME:
 +      if (value == null) {
 +        unsetTableName();
 +      } else {
 +        setTableName((String)value);
 +      }
 +      break;
 +
 +    case PARTITIONS:
 +      if (value == null) {
 +        unsetPartitions();
 +      } else {
 +        setPartitions((List<Partition>)value);
 +      }
 +      break;
 +
 +    case ENVIRONMENT_CONTEXT:
 +      if (value == null) {
 +        unsetEnvironmentContext();
 +      } else {
 +        setEnvironmentContext((EnvironmentContext)value);
 +      }
 +      break;
 +
 +    case TXN_ID:
 +      if (value == null) {
 +        unsetTxnId();
 +      } else {
 +        setTxnId((Long)value);
 +      }
 +      break;
 +
 +    case WRITE_ID:
 +      if (value == null) {
 +        unsetWriteId();
 +      } else {
 +        setWriteId((Long)value);
 +      }
 +      break;
 +
 +    case VALID_WRITE_ID_LIST:
 +      if (value == null) {
 +        unsetValidWriteIdList();
 +      } else {
 +        setValidWriteIdList((String)value);
 +      }
 +      break;
 +
 +    }
 +  }
 +
 +  public Object getFieldValue(_Fields field) {
 +    switch (field) {
 +    case CAT_NAME:
 +      return getCatName();
 +
 +    case DB_NAME:
 +      return getDbName();
 +
 +    case TABLE_NAME:
 +      return getTableName();
 +
 +    case PARTITIONS:
 +      return getPartitions();
 +
 +    case ENVIRONMENT_CONTEXT:
 +      return getEnvironmentContext();
 +
 +    case TXN_ID:
 +      return getTxnId();
 +
 +    case WRITE_ID:
 +      return getWriteId();
 +
 +    case VALID_WRITE_ID_LIST:
 +      return getValidWriteIdList();
 +
 +    }
 +    throw new IllegalStateException();
 +  }
 +
 +  /** Returns true if field corresponding to fieldID is set (has been assigned a value) and false otherwise */
 +  public boolean isSet(_Fields field) {
 +    if (field == null) {
 +      throw new IllegalArgumentException();
 +    }
 +
 +    switch (field) {
 +    case CAT_NAME:
 +      return isSetCatName();
 +    case DB_NAME:
 +      return isSetDbName();
 +    case TABLE_NAME:
 +      return isSetTableName();
 +    case PARTITIONS:
 +      return isSetPartitions();
 +    case ENVIRONMENT_CONTEXT:
 +      return isSetEnvironmentContext();
 +    case TXN_ID:
 +      return isSetTxnId();
 +    case WRITE_ID:
 +      return isSetWriteId();
 +    case VALID_WRITE_ID_LIST:
 +      return isSetValidWriteIdList();
 +    }
 +    throw new IllegalStateException();
 +  }
 +
 +  @Override
 +  public boolean equals(Object that) {
 +    if (that == null)
 +      return false;
 +    if (that instanceof AlterPartitionsRequest)
 +      return this.equals((AlterPartitionsRequest)that);
 +    return false;
 +  }
 +
 +  public boolean equals(AlterPartitionsRequest that) {
 +    if (that == null)
 +      return false;
 +
 +    boolean this_present_catName = true && this.isSetCatName();
 +    boolean that_present_catName = true && that.isSetCatName();
 +    if (this_present_catName || that_present_catName) {
 +      if (!(this_present_catName && that_present_catName))
 +        return false;
 +      if (!this.catName.equals(that.catName))
 +        return false;
 +    }
 +
 +    boolean this_present_dbName = true && this.isSetDbName();
 +    boolean that_present_dbName = true && that.isSetDbName();
 +    if (this_present_dbName || that_present_dbName) {
 +      if (!(this_present_dbName && that_present_dbName))
 +        return false;
 +      if (!this.dbName.equals(that.dbName))
 +        return false;
 +    }
 +
 +    boolean this_present_tableName = true && this.isSetTableName();
 +    boolean that_present_tableName = true && that.isSetTableName();
 +    if (this_present_tableName || that_present_tableName) {
 +      if (!(this_present_tableName && that_present_tableName))
 +        return false;
 +      if (!this.tableName.equals(that.tableName))
 +        return false;
 +    }
 +
 +    boolean this_present_partitions = true && this.isSetPartitions();
 +    boolean that_present_partitions = true && that.isSetPartitions();
 +    if (this_present_partitions || that_present_partitions) {
 +      if (!(this_present_partitions && that_present_partitions))
 +        return false;
 +      if (!this.partitions.equals(that.partitions))
 +        return false;
 +    }
 +
 +    boolean this_present_environmentContext = true && this.isSetEnvironmentContext();
 +    boolean that_present_environmentContext = true && that.isSetEnvironmentContext();
 +    if (this_present_environmentContext || that_present_environmentContext) {
 +      if (!(this_present_environmentContext && that_present_environmentContext))
 +        return false;
 +      if (!this.environmentContext.equals(that.environmentContext))
 +        return false;
 +    }
 +
 +    boolean this_present_txnId = true && this.isSetTxnId();
 +    boolean that_present_txnId = true && that.isSetTxnId();
 +    if (this_present_txnId || that_present_txnId) {
 +      if (!(this_present_txnId && that_present_txnId))
 +        return false;
 +      if (this.txnId != that.txnId)
 +        return false;
 +    }
 +
 +    boolean this_present_writeId = true && this.isSetWriteId();
 +    boolean that_present_writeId = true && that.isSetWriteId();
 +    if (this_present_writeId || that_present_writeId) {
 +      if (!(this_present_writeId && that_present_writeId))
 +        return false;
 +      if (this.writeId != that.writeId)
 +        return false;
 +    }
 +
 +    boolean this_present_validWriteIdList = true && this.isSetValidWriteIdList();
 +    boolean that_present_validWriteIdList = true && that.isSetValidWriteIdList();
 +    if (this_present_validWriteIdList || that_present_validWriteIdList) {
 +      if (!(this_present_validWriteIdList && that_present_validWriteIdList))
 +        return false;
 +      if (!this.validWriteIdList.equals(that.validWriteIdList))
 +        return false;
 +    }
 +
 +    return true;
 +  }
 +
 +  @Override
 +  public int hashCode() {
 +    List<Object> list = new ArrayList<Object>();
 +
 +    boolean present_catName = true && (isSetCatName());
 +    list.add(present_catName);
 +    if (present_catName)
 +      list.add(catName);
 +
 +    boolean present_dbName = true && (isSetDbName());
 +    list.add(present_dbName);
 +    if (present_dbName)
 +      list.add(dbName);
 +
 +    boolean present_tableName = true && (isSetTableName());
 +    list.add(present_tableName);
 +    if (present_tableName)
 +      list.add(tableName);
 +
 +    boolean present_partitions = true && (isSetPartitions());
 +    list.add(present_partitions);
 +    if (present_partitions)
 +      list.add(partitions);
 +
 +    boolean present_environmentContext = true && (isSetEnvironmentContext());
 +    list.add(present_environmentContext);
 +    if (present_environmentContext)
 +      list.add(environmentContext);
 +
 +    boolean present_txnId = true && (isSetTxnId());
 +    list.add(present_txnId);
 +    if (present_txnId)
 +      list.add(txnId);
 +
 +    boolean present_writeId = true && (isSetWriteId());
 +    list.add(present_writeId);
 +    if (present_writeId)
 +      list.add(writeId);
 +
 +    boolean present_validWriteIdList = true && (isSetValidWriteIdList());
 +    list.add(present_validWriteIdList);
 +    if (present_validWriteIdList)
 +      list.add(validWriteIdList);
 +
 +    return list.hashCode();
 +  }
 +
 +  @Override
 +  public int compareTo(AlterPartitionsRequest other) {
 +    if (!getClass().equals(other.getClass())) {
 +      return getClass().getName().compareTo(other.getClass().getName());
 +    }
 +
 +    int lastComparison = 0;
 +
 +    lastComparison = Boolean.valueOf(isSetCatName()).compareTo(other.isSetCatName());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetCatName()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.catName, other.catName);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetDbName()).compareTo(other.isSetDbName());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetDbName()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.dbName, other.dbName);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetTableName()).compareTo(other.isSetTableName());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetTableName()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.tableName, other.tableName);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetPartitions()).compareTo(other.isSetPartitions());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetPartitions()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.partitions, other.partitions);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetEnvironmentContext()).compareTo(other.isSetEnvironmentContext());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetEnvironmentContext()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.environmentContext, other.environmentContext);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetTxnId()).compareTo(other.isSetTxnId());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetTxnId()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.txnId, other.txnId);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetWriteId()).compareTo(other.isSetWriteId());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetWriteId()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.writeId, other.writeId);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    lastComparison = Boolean.valueOf(isSetValidWriteIdList()).compareTo(other.isSetValidWriteIdList());
 +    if (lastComparison != 0) {
 +      return lastComparison;
 +    }
 +    if (isSetValidWriteIdList()) {
 +      lastComparison = org.apache.thrift.TBaseHelper.compareTo(this.validWriteIdList, other.validWriteIdList);
 +      if (lastComparison != 0) {
 +        return lastComparison;
 +      }
 +    }
 +    return 0;
 +  }
 +
 +  public _Fields fieldForId(int fieldId) {
 +    return _Fields.findByThriftId(fieldId);
 +  }
 +
 +  public void read(org.apache.thrift.protocol.TProtocol iprot) throws org.apache.thrift.TException {
 +    schemes.get(iprot.getScheme()).getScheme().read(iprot, this);
 +  }
 +
 +  public void write(org.apache.thrift.protocol.TProtocol oprot) throws org.apache.thrift.TException {
 +    schemes.get(oprot.getScheme()).getScheme().write(oprot, this);
 +  }
 +
 +  @Override
 +  public String toString() {
 +    StringBuilder sb = new StringBuilder("AlterPartitionsRequest(");
 +    boolean first = true;
 +
 +    if (isSetCatName()) {
 +      sb.append("catName:");
 +      if (this.catName == null) {
 +        sb.append("null");
 +      } else {
 +        sb.append(this.catName);
 +      }
 +      first = false;
 +    }
 +    if (!first) sb.append(", ");
 +    sb.append("dbName:");
 +    if (this.dbName == null) {
 +      sb.append("null");
 +    } else {
 +      sb.append(this.dbName);
 +    }
 +    first = false;
 +    if (!first) sb.append(", ");
 +    sb.append("tableName:");
 +    if (this.tableName == null) {
 +      sb.append("null");
 +    } else {
 +      sb.append(this.tableName);
 +    }
 +    first = false;
 +    if (!first) sb.append(", ");
 +    sb.append("partitions:");
 +    if (this.partitions == null) {
 +      sb.append("null");
 +    } else {
 +      sb.append(this.partitions);
 +    }
 +    first = false;
 +    if (isSetEnvironmentContext()) {
 +      if (!first) sb.append(", ");
 +      sb.append("environmentContext:");
 +      if (this.environmentContext == null) {
 +        sb.append("null");
 +      } else {
 +        sb.append(this.environmentContext);
 +      }
 +      first = false;
 +    }
 +    if (isSetTxnId()) {
 +      if (!first) sb.append(", ");
 +      sb.append("txnId:");
 +      sb.append(this.txnId);
 +      first = false;
 +    }
 +    if (isSetWriteId()) {
 +      if (!first) sb.append(", ");
 +      sb.append("writeId:");
 +      sb.append(this.writeId);
 +      first = false;
 +    }
 +    if (isSetValidWriteIdList()) {
 +      if (!first) sb.append(", ");
 +      sb.append("validWriteIdList:");
 +      if (this.validWriteIdList == null) {
 +        sb.append("null");
 +      } else {
 +        sb.append(this.validWriteIdList);
 +      }
 +      first = false;
 +    }
 +    sb.append(")");
 +    return sb.toString();
 +  }
 +
 +  public void validate() throws org.apache.thrift.TException {
 +    // check for required fields
 +    if (!isSetDbName()) {
 +      throw new org.apache.thrift.protocol.TProtocolException("Required field 'dbName' is unset! Struct:" + toString());
 +    }
 +
 +    if (!isSetTableName()) {
 +      throw new org.apache.thrift.protocol.TProtocolException("Required field 'tableName' is unset! Struct:" + toString());
 +    }
 +
 +    if (!isSetPartitions()) {
 +      throw new org.apache.thrift.protocol.TProtocolException("Required field 'partitions' is unset! Struct:" + toString());
 +    }
 +
 +    // check for sub-struct validity
 +    if (environmentContext != null) {
 +      environmentContext.validate();
 +    }
 +  }
 +
 +  private void writeObject(java.io.ObjectOutputStream out) throws java.io.IOException {
 +    try {
 +      write(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(out)));
 +    } catch (org.apache.thrift.TException te) {
 +      throw new java.io.IOException(te);
 +    }
 +  }
 +
 +  private void readObject(java.io.ObjectInputStream in) throws java.io.IOException, ClassNotFoundException {
 +    try {
 +      // it doesn't seem like you should have to do this, but java serialization is wacky, and doesn't call the default constructor.
 +      __isset_bitfield = 0;
 +      read(new org.apache.thrift.protocol.TCompactProtocol(new org.apache.thrift.transport.TIOStreamTransport(in)));
 +    } catch (org.apache.thrift.TException te) {
 +      throw new java.io.IOException(te);
 +    }
 +  }
 +
 +  private static class AlterPartitionsRequestStandardSchemeFactory implements SchemeFactory {
 +    public AlterPartitionsRequestStandardScheme getScheme() {
 +      return new AlterPartitionsRequestStandardScheme();
 +    }
 +  }
 +
 +  private static class AlterPartitionsRequestStandardScheme extends StandardScheme<AlterPartitionsRequest> {
 +
 +    public void read(org.apache.thrift.protocol.TProtocol iprot, AlterPartitionsRequest struct) throws org.apache.thrift.TException {
 +      org.apache.thrift.protocol.TField schemeField;
 +      iprot.readStructBegin();
 +      while (true)
 +      {
 +        schemeField = iprot.readFieldBegin();
 +        if (schemeField.type == org.apache.thrift.protocol.TType.STOP) { 
 +          break;
 +        }
 +        switch (schemeField.id) {
 +          case 1: // CAT_NAME
 +            if (schemeField.type == org.apache.thrift.protocol.TType.STRING) {
 +              struct.catName = iprot.readString();
 +              struct.setCatNameIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 2: // DB_NAME
 +            if (schemeField.type == org.apache.thrift.protocol.TType.STRING) {
 +              struct.dbName = iprot.readString();
 +              struct.setDbNameIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 3: // TABLE_NAME
 +            if (schemeField.type == org.apache.thrift.protocol.TType.STRING) {
 +              struct.tableName = iprot.readString();
 +              struct.setTableNameIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 4: // PARTITIONS
 +            if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
 +              {
-                 org.apache.thrift.protocol.TList _list960 = iprot.readListBegin();
-                 struct.partitions = new ArrayList<Partition>(_list960.size);
-                 Partition _elem961;
-                 for (int _i962 = 0; _i962 < _list960.size; ++_i962)
++                org.apache.thrift.protocol.TList _list952 = iprot.readListBegin();
++                struct.partitions = new ArrayList<Partition>(_list952.size);
++                Partition _elem953;
++                for (int _i954 = 0; _i954 < _list952.size; ++_i954)
 +                {
-                   _elem961 = new Partition();
-                   _elem961.read(iprot);
-                   struct.partitions.add(_elem961);
++                  _elem953 = new Partition();
++                  _elem953.read(iprot);
++                  struct.partitions.add(_elem953);
 +                }
 +                iprot.readListEnd();
 +              }
 +              struct.setPartitionsIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 5: // ENVIRONMENT_CONTEXT
 +            if (schemeField.type == org.apache.thrift.protocol.TType.STRUCT) {
 +              struct.environmentContext = new EnvironmentContext();
 +              struct.environmentContext.read(iprot);
 +              struct.setEnvironmentContextIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 6: // TXN_ID
 +            if (schemeField.type == org.apache.thrift.protocol.TType.I64) {
 +              struct.txnId = iprot.readI64();
 +              struct.setTxnIdIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 7: // WRITE_ID
 +            if (schemeField.type == org.apache.thrift.protocol.TType.I64) {
 +              struct.writeId = iprot.readI64();
 +              struct.setWriteIdIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          case 8: // VALID_WRITE_ID_LIST
 +            if (schemeField.type == org.apache.thrift.protocol.TType.STRING) {
 +              struct.validWriteIdList = iprot.readString();
 +              struct.setValidWriteIdListIsSet(true);
 +            } else { 
 +              org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +            }
 +            break;
 +          default:
 +            org.apache.thrift.protocol.TProtocolUtil.skip(iprot, schemeField.type);
 +        }
 +        iprot.readFieldEnd();
 +      }
 +      iprot.readStructEnd();
 +      struct.validate();
 +    }
 +
 +    public void write(org.apache.thrift.protocol.TProtocol oprot, AlterPartitionsRequest struct) throws org.apache.thrift.TException {
 +      struct.validate();
 +
 +      oprot.writeStructBegin(STRUCT_DESC);
 +      if (struct.catName != null) {
 +        if (struct.isSetCatName()) {
 +          oprot.writeFieldBegin(CAT_NAME_FIELD_DESC);
 +          oprot.writeString(struct.catName);
 +          oprot.writeFieldEnd();
 +        }
 +      }
 +      if (struct.dbName != null) {
 +        oprot.writeFieldBegin(DB_NAME_FIELD_DESC);
 +        oprot.writeString(struct.dbName);
 +        oprot.writeFieldEnd();
 +      }
 +      if (struct.tableName != null) {
 +        oprot.writeFieldBegin(TABLE_NAME_FIELD_DESC);
 +        oprot.writeString(struct.tableName);
 +        oprot.writeFieldEnd();
 +      }
 +      if (struct.partitions != null) {
 +        oprot.writeFieldBegin(PARTITIONS_FIELD_DESC);
 +        {
 +          oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.partitions.size()));
-           for (Partition _iter963 : struct.partitions)
++          for (Partition _iter955 : struct.partitions)
 +          {
-             _iter963.write(oprot);
++            _iter955.write(oprot);
 +          }
 +          oprot.writeListEnd();
 +        }
 +        oprot.writeFieldEnd();
 +      }
 +      if (struct.environmentContext != null) {
 +        if (struct.isSetEnvironmentContext()) {
 +          oprot.writeFieldBegin(ENVIRONMENT_CONTEXT_FIELD_DESC);
 +          struct.environmentContext.write(oprot);
 +          oprot.writeFieldEnd();
 +        }
 +      }
 +      if (struct.isSetTxnId()) {
 +        oprot.writeFieldBegin(TXN_ID_FIELD_DESC);
 +        oprot.writeI64(struct.txnId);
 +        oprot.writeFieldEnd();
 +      }
 +      if (struct.isSetWriteId()) {
 +        oprot.writeFieldBegin(WRITE_ID_FIELD_DESC);
 +        oprot.writeI64(struct.writeId);
 +        oprot.writeFieldEnd();
 +      }
 +      if (struct.validWriteIdList != null) {
 +        if (struct.isSetValidWriteIdList()) {
 +          oprot.writeFieldBegin(VALID_WRITE_ID_LIST_FIELD_DESC);
 +          oprot.writeString(struct.validWriteIdList);
 +          oprot.writeFieldEnd();
 +        }
 +      }
 +      oprot.writeFieldStop();
 +      oprot.writeStructEnd();
 +    }
 +
 +  }
 +
 +  private static class AlterPartitionsRequestTupleSchemeFactory implements SchemeFactory {
 +    public AlterPartitionsRequestTupleScheme getScheme() {
 +      return new AlterPartitionsRequestTupleScheme();
 +    }
 +  }
 +
 +  private static class AlterPartitionsRequestTupleScheme extends TupleScheme<AlterPartitionsRequest> {
 +
 +    @Override
 +    public void write(org.apache.thrift.protocol.TProtocol prot, AlterPartitionsRequest struct) throws org.apache.thrift.TException {
 +      TTupleProtocol oprot = (TTupleProtocol) prot;
 +      oprot.writeString(struct.dbName);
 +      oprot.writeString(struct.tableName);
 +      {
 +        oprot.writeI32(struct.partitions.size());
-         for (Partition _iter964 : struct.partitions)
++        for (Partition _iter956 : struct.partitions)
 +        {
-           _iter964.write(oprot);
++          _iter956.write(oprot);
 +        }
 +      }
 +      BitSet optionals = new BitSet();
 +      if (struct.isSetCatName()) {
 +        optionals.set(0);
 +      }
 +      if (struct.isSetEnvironmentContext()) {
 +        optionals.set(1);
 +      }
 +      if (struct.isSetTxnId()) {
 +        optionals.set(2);
 +      }
 +      if (struct.isSetWriteId()) {
 +        optionals.set(3);
 +      }
 +      if (struct.isSetValidWriteIdList()) {
 +        optionals.set(4);
 +      }
 +      oprot.writeBitSet(optionals, 5);
 +      if (struct.isSetCatName()) {
 +        oprot.writeString(struct.catName);
 +      }
 +      if (struct.isSetEnvironmentContext()) {
 +        struct.environmentContext.write(oprot);
 +      }
 +      if (struct.isSetTxnId()) {
 +        oprot.writeI64(struct.txnId);
 +      }
 +      if (struct.isSetWriteId()) {
 +        oprot.writeI64(struct.writeId);
 +      }
 +      if (struct.isSetValidWriteIdList()) {
 +        oprot.writeString(struct.validWriteIdList);
 +      }
 +    }
 +
 +    @Override
 +    public void read(org.apache.thrift.protocol.TProtocol prot, AlterPartitionsRequest struct) throws org.apache.thrift.TException {
 +      TTupleProtocol iprot = (TTupleProtocol) prot;
 +      struct.dbName = iprot.readString();
 +      struct.setDbNameIsSet(true);
 +      struct.tableName = iprot.readString();
 +      struct.setTableNameIsSet(true);
 +      {
-         org.apache.thrift.protocol.TList _list965 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-         struct.partitions = new ArrayList<Partition>(_list965.size);
-         Partition _elem966;
-         for (int _i967 = 0; _i967 < _list965.size; ++_i967)
++        org.apache.thrift.protocol.TList _list957 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
++        struct.partitions = new ArrayList<Partition>(_list957.size);
++        Partition _elem958;
++        for (int _i959 = 0; _i959 < _list957.size; ++_i959)
 +        {
-           _elem966 = new Partition();
-           _elem966.read(iprot);
-           struct.partitions.add(_elem966);
++          _elem958 = new Partition();
++          _elem958.read(iprot);
++          struct.partitions.add(_elem958);
 +        }
 +      }
 +      struct.setPartitionsIsSet(true);
 +      BitSet incoming = iprot.readBitSet(5);
 +      if (incoming.get(0)) {
 +        struct.catName = iprot.readString();
 +        struct.setCatNameIsSet(true);
 +      }
 +      if (incoming.get(1)) {
 +        struct.environmentContext = new EnvironmentContext();
 +        struct.environmentContext.read(iprot);
 +        struct.setEnvironmentContextIsSet(true);
 +      }
 +      if (incoming.get(2)) {
 +        struct.txnId = iprot.readI64();
 +        struct.setTxnIdIsSet(true);
 +      }
 +      if (incoming.get(3)) {
 +        struct.writeId = iprot.readI64();
 +        struct.setWriteIdIsSet(true);
 +      }
 +      if (incoming.get(4)) {
 +        struct.validWriteIdList = iprot.readString();
 +        struct.setValidWriteIdListIsSet(true);
 +      }
 +    }
 +  }
 +
 +}
 +

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/CreationMetadata.java
----------------------------------------------------------------------

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FindSchemasByColsResp.java
----------------------------------------------------------------------
diff --cc standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FindSchemasByColsResp.java
index f2f8fb4,79d9fc6..8f5b4e5
--- a/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FindSchemasByColsResp.java
+++ b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/FindSchemasByColsResp.java
@@@ -350,14 -350,14 +350,14 @@@ import org.slf4j.LoggerFactory
            case 1: // SCHEMA_VERSIONS
              if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                {
-                 org.apache.thrift.protocol.TList _list952 = iprot.readListBegin();
-                 struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list952.size);
-                 SchemaVersionDescriptor _elem953;
-                 for (int _i954 = 0; _i954 < _list952.size; ++_i954)
 -                org.apache.thrift.protocol.TList _list936 = iprot.readListBegin();
 -                struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list936.size);
 -                SchemaVersionDescriptor _elem937;
 -                for (int _i938 = 0; _i938 < _list936.size; ++_i938)
++                org.apache.thrift.protocol.TList _list944 = iprot.readListBegin();
++                struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list944.size);
++                SchemaVersionDescriptor _elem945;
++                for (int _i946 = 0; _i946 < _list944.size; ++_i946)
                  {
-                   _elem953 = new SchemaVersionDescriptor();
-                   _elem953.read(iprot);
-                   struct.schemaVersions.add(_elem953);
 -                  _elem937 = new SchemaVersionDescriptor();
 -                  _elem937.read(iprot);
 -                  struct.schemaVersions.add(_elem937);
++                  _elem945 = new SchemaVersionDescriptor();
++                  _elem945.read(iprot);
++                  struct.schemaVersions.add(_elem945);
                  }
                  iprot.readListEnd();
                }
@@@ -383,9 -383,9 +383,9 @@@
          oprot.writeFieldBegin(SCHEMA_VERSIONS_FIELD_DESC);
          {
            oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.schemaVersions.size()));
-           for (SchemaVersionDescriptor _iter955 : struct.schemaVersions)
 -          for (SchemaVersionDescriptor _iter939 : struct.schemaVersions)
++          for (SchemaVersionDescriptor _iter947 : struct.schemaVersions)
            {
-             _iter955.write(oprot);
 -            _iter939.write(oprot);
++            _iter947.write(oprot);
            }
            oprot.writeListEnd();
          }
@@@ -416,9 -416,9 +416,9 @@@
        if (struct.isSetSchemaVersions()) {
          {
            oprot.writeI32(struct.schemaVersions.size());
-           for (SchemaVersionDescriptor _iter956 : struct.schemaVersions)
 -          for (SchemaVersionDescriptor _iter940 : struct.schemaVersions)
++          for (SchemaVersionDescriptor _iter948 : struct.schemaVersions)
            {
-             _iter956.write(oprot);
 -            _iter940.write(oprot);
++            _iter948.write(oprot);
            }
          }
        }
@@@ -430,14 -430,14 +430,14 @@@
        BitSet incoming = iprot.readBitSet(1);
        if (incoming.get(0)) {
          {
-           org.apache.thrift.protocol.TList _list957 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-           struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list957.size);
-           SchemaVersionDescriptor _elem958;
-           for (int _i959 = 0; _i959 < _list957.size; ++_i959)
 -          org.apache.thrift.protocol.TList _list941 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
 -          struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list941.size);
 -          SchemaVersionDescriptor _elem942;
 -          for (int _i943 = 0; _i943 < _list941.size; ++_i943)
++          org.apache.thrift.protocol.TList _list949 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
++          struct.schemaVersions = new ArrayList<SchemaVersionDescriptor>(_list949.size);
++          SchemaVersionDescriptor _elem950;
++          for (int _i951 = 0; _i951 < _list949.size; ++_i951)
            {
-             _elem958 = new SchemaVersionDescriptor();
-             _elem958.read(iprot);
-             struct.schemaVersions.add(_elem958);
 -            _elem942 = new SchemaVersionDescriptor();
 -            _elem942.read(iprot);
 -            struct.schemaVersions.add(_elem942);
++            _elem950 = new SchemaVersionDescriptor();
++            _elem950.read(iprot);
++            struct.schemaVersions.add(_elem950);
            }
          }
          struct.setSchemaVersionsIsSet(true);

http://git-wip-us.apache.org/repos/asf/hive/blob/37a1907b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SchemaVersion.java
----------------------------------------------------------------------
diff --cc standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SchemaVersion.java
index dd16932,935af04..88d7e3f
--- a/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SchemaVersion.java
+++ b/standalone-metastore/metastore-common/src/gen/thrift/gen-javabean/org/apache/hadoop/hive/metastore/api/SchemaVersion.java
@@@ -1119,14 -1119,14 +1119,14 @@@ import org.slf4j.LoggerFactory
            case 4: // COLS
              if (schemeField.type == org.apache.thrift.protocol.TType.LIST) {
                {
-                 org.apache.thrift.protocol.TList _list944 = iprot.readListBegin();
-                 struct.cols = new ArrayList<FieldSchema>(_list944.size);
-                 FieldSchema _elem945;
-                 for (int _i946 = 0; _i946 < _list944.size; ++_i946)
 -                org.apache.thrift.protocol.TList _list928 = iprot.readListBegin();
 -                struct.cols = new ArrayList<FieldSchema>(_list928.size);
 -                FieldSchema _elem929;
 -                for (int _i930 = 0; _i930 < _list928.size; ++_i930)
++                org.apache.thrift.protocol.TList _list936 = iprot.readListBegin();
++                struct.cols = new ArrayList<FieldSchema>(_list936.size);
++                FieldSchema _elem937;
++                for (int _i938 = 0; _i938 < _list936.size; ++_i938)
                  {
-                   _elem945 = new FieldSchema();
-                   _elem945.read(iprot);
-                   struct.cols.add(_elem945);
 -                  _elem929 = new FieldSchema();
 -                  _elem929.read(iprot);
 -                  struct.cols.add(_elem929);
++                  _elem937 = new FieldSchema();
++                  _elem937.read(iprot);
++                  struct.cols.add(_elem937);
                  }
                  iprot.readListEnd();
                }
@@@ -1212,9 -1212,9 +1212,9 @@@
          oprot.writeFieldBegin(COLS_FIELD_DESC);
          {
            oprot.writeListBegin(new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, struct.cols.size()));
-           for (FieldSchema _iter947 : struct.cols)
 -          for (FieldSchema _iter931 : struct.cols)
++          for (FieldSchema _iter939 : struct.cols)
            {
-             _iter947.write(oprot);
 -            _iter931.write(oprot);
++            _iter939.write(oprot);
            }
            oprot.writeListEnd();
          }
@@@ -1323,9 -1323,9 +1323,9 @@@
        if (struct.isSetCols()) {
          {
            oprot.writeI32(struct.cols.size());
-           for (FieldSchema _iter948 : struct.cols)
 -          for (FieldSchema _iter932 : struct.cols)
++          for (FieldSchema _iter940 : struct.cols)
            {
-             _iter948.write(oprot);
 -            _iter932.write(oprot);
++            _iter940.write(oprot);
            }
          }
        }
@@@ -1368,14 -1368,14 +1368,14 @@@
        }
        if (incoming.get(3)) {
          {
-           org.apache.thrift.protocol.TList _list949 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
-           struct.cols = new ArrayList<FieldSchema>(_list949.size);
-           FieldSchema _elem950;
-           for (int _i951 = 0; _i951 < _list949.size; ++_i951)
 -          org.apache.thrift.protocol.TList _list933 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
 -          struct.cols = new ArrayList<FieldSchema>(_list933.size);
 -          FieldSchema _elem934;
 -          for (int _i935 = 0; _i935 < _list933.size; ++_i935)
++          org.apache.thrift.protocol.TList _list941 = new org.apache.thrift.protocol.TList(org.apache.thrift.protocol.TType.STRUCT, iprot.readI32());
++          struct.cols = new ArrayList<FieldSchema>(_list941.size);
++          FieldSchema _elem942;
++          for (int _i943 = 0; _i943 < _list941.size; ++_i943)
            {
-             _elem950 = new FieldSchema();
-             _elem950.read(iprot);
-             struct.cols.add(_elem950);
 -            _elem934 = new FieldSchema();
 -            _elem934.read(iprot);
 -            struct.cols.add(_elem934);
++            _elem942 = new FieldSchema();
++            _elem942.read(iprot);
++            struct.cols.add(_elem942);
            }
          }
          struct.setColsIsSet(true);