You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by ha...@apache.org on 2015/01/16 17:45:14 UTC

svn commit: r1652450 - in /hive/trunk/ql/src: java/org/apache/hadoop/hive/ql/optimizer/ test/queries/clientpositive/ test/results/clientpositive/ test/results/clientpositive/spark/ test/results/clientpositive/tez/

Author: hashutosh
Date: Fri Jan 16 16:45:13 2015
New Revision: 1652450

URL: http://svn.apache.org/r1652450
Log:
HIVE-9112 : Query may generate different results depending on the number of reducers (Ted Xu via Ashutosh Chauhan, Chao Sun)

Modified:
    hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/optimizer/ConstantPropagateProcFactory.java
    hive/trunk/ql/src/test/queries/clientpositive/constprog_partitioner.q
    hive/trunk/ql/src/test/results/clientpositive/cluster.q.out
    hive/trunk/ql/src/test/results/clientpositive/constprog2.q.out
    hive/trunk/ql/src/test/results/clientpositive/constprog_partitioner.q.out
    hive/trunk/ql/src/test/results/clientpositive/identity_project_remove_skip.q.out
    hive/trunk/ql/src/test/results/clientpositive/join_nullsafe.q.out
    hive/trunk/ql/src/test/results/clientpositive/ppd2.q.out
    hive/trunk/ql/src/test/results/clientpositive/ppd_clusterby.q.out
    hive/trunk/ql/src/test/results/clientpositive/ppd_join4.q.out
    hive/trunk/ql/src/test/results/clientpositive/ppd_outer_join5.q.out
    hive/trunk/ql/src/test/results/clientpositive/ppd_union_view.q.out
    hive/trunk/ql/src/test/results/clientpositive/regex_col.q.out
    hive/trunk/ql/src/test/results/clientpositive/smb_mapjoin_25.q.out
    hive/trunk/ql/src/test/results/clientpositive/spark/ppd_join4.q.out
    hive/trunk/ql/src/test/results/clientpositive/spark/ppd_outer_join5.q.out
    hive/trunk/ql/src/test/results/clientpositive/spark/smb_mapjoin_25.q.out
    hive/trunk/ql/src/test/results/clientpositive/spark/vector_mapjoin_reduce.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning_2.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/join_nullsafe.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/vector_decimal_mapjoin.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/vector_mapjoin_reduce.q.out
    hive/trunk/ql/src/test/results/clientpositive/tez/vectorized_dynamic_partition_pruning.q.out
    hive/trunk/ql/src/test/results/clientpositive/union27.q.out
    hive/trunk/ql/src/test/results/clientpositive/vector_mapjoin_reduce.q.out

Modified: hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/optimizer/ConstantPropagateProcFactory.java
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/optimizer/ConstantPropagateProcFactory.java?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/optimizer/ConstantPropagateProcFactory.java (original)
+++ hive/trunk/ql/src/java/org/apache/hadoop/hive/ql/optimizer/ConstantPropagateProcFactory.java Fri Jan 16 16:45:13 2015
@@ -863,7 +863,7 @@ public final class ConstantPropagateProc
       if (op.getChildOperators().size() == 1
           && op.getChildOperators().get(0) instanceof JoinOperator) {
         JoinOperator joinOp = (JoinOperator) op.getChildOperators().get(0);
-        if (skipFolding(joinOp.getConf(), rsDesc.getTag())) {
+        if (skipFolding(joinOp.getConf())) {
           LOG.debug("Skip folding in outer join " + op);
           cppCtx.getOpToConstantExprs().put(op, new HashMap<ColumnInfo, ExprNodeDesc>());
           return null;
@@ -889,22 +889,16 @@ public final class ConstantPropagateProc
       rsDesc.setKeyCols(newKeyEpxrs);
 
       // partition columns
-      if (!rsDesc.getPartitionCols().isEmpty()) {
-        ArrayList<ExprNodeDesc> newPartExprs = new ArrayList<ExprNodeDesc>();
-        for (ExprNodeDesc desc : rsDesc.getPartitionCols()) {
-          ExprNodeDesc expr = foldExpr(desc, constants, cppCtx, op, 0, false);
-          if (expr instanceof ExprNodeConstantDesc || expr instanceof ExprNodeNullDesc) {
-            continue;
-          }
-          newPartExprs.add(expr);
+      ArrayList<ExprNodeDesc> newPartExprs = new ArrayList<ExprNodeDesc>();
+      for (ExprNodeDesc desc : rsDesc.getPartitionCols()) {
+        ExprNodeDesc expr = foldExpr(desc, constants, cppCtx, op, 0, false);
+        if (expr != desc && desc instanceof ExprNodeColumnDesc
+            && expr instanceof ExprNodeConstantDesc) {
+          ((ExprNodeConstantDesc) expr).setFoldedFromCol(((ExprNodeColumnDesc) desc).getColumn());
         }
-        if (newPartExprs.isEmpty()) {
-          // If all partition columns are removed because of constant, insert an extra column to avoid
-          // random partitioning.
-          newPartExprs.add(new ExprNodeConstantDesc(""));
-        }
-        rsDesc.setPartitionCols(newPartExprs);
+        newPartExprs.add(expr);
       }
+      rsDesc.setPartitionCols(newPartExprs);
 
       // value columns
       ArrayList<ExprNodeDesc> newValExprs = new ArrayList<ExprNodeDesc>();
@@ -916,28 +910,19 @@ public final class ConstantPropagateProc
       return null;
     }
 
-    private boolean skipFolding(JoinDesc joinDesc, int tag) {
-      JoinCondDesc[] conds = joinDesc.getConds();
-      int i;
-      for (i = conds.length - 1; i >= 0; i--) {
-        if (conds[i].getType() == JoinDesc.INNER_JOIN) {
-          if (tag == i + 1)
-            return false;
-        } else if (conds[i].getType() == JoinDesc.FULL_OUTER_JOIN) {
-          return true;
-        } else if (conds[i].getType() == JoinDesc.RIGHT_OUTER_JOIN) {
-          if (tag == i + 1)
-            return false;
-          return true;
-        } else if (conds[i].getType() == JoinDesc.LEFT_OUTER_JOIN) {
-          if (tag == i + 1)
-            return true;
+    /**
+     * Skip folding constants if there is outer join in join tree.
+     * @param joinDesc
+     * @return true if to skip.
+     */
+    private boolean skipFolding(JoinDesc joinDesc) {
+      for (JoinCondDesc cond : joinDesc.getConds()) {
+        if (cond.getType() == JoinDesc.INNER_JOIN || cond.getType() == JoinDesc.UNIQUE_JOIN) {
+          continue;
         }
+        return true;
       }
-      if (tag == 0) {
-        return false;
-      }
-      return true;
+      return false;
     }
 
   }

Modified: hive/trunk/ql/src/test/queries/clientpositive/constprog_partitioner.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientpositive/constprog_partitioner.q?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientpositive/constprog_partitioner.q (original)
+++ hive/trunk/ql/src/test/queries/clientpositive/constprog_partitioner.q Fri Jan 16 16:45:13 2015
@@ -9,3 +9,16 @@ SELECT src1.key, src1.key + 1, src2.valu
 
 SELECT src1.key, src1.key + 1, src2.value
        FROM src src1 join src src2 ON src1.key = src2.key AND src1.key = 100;
+
+EXPLAIN
+SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+;
+
+SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+;

Modified: hive/trunk/ql/src/test/results/clientpositive/cluster.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/cluster.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/cluster.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/cluster.q.out Fri Jan 16 16:45:13 2015
@@ -25,7 +25,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '10' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '10' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -83,7 +83,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -141,7 +141,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -199,7 +199,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -257,7 +257,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -315,7 +315,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -430,7 +430,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '20' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '20' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -485,7 +485,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -497,7 +497,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -576,7 +576,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -588,7 +588,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
       Reduce Operator Tree:
@@ -673,7 +673,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -685,7 +685,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
       Reduce Operator Tree:
@@ -715,7 +715,7 @@ STAGE PLANS:
             Reduce Output Operator
               key expressions: '20' (type: string)
               sort order: +
-              Map-reduce partition columns: '' (type: string)
+              Map-reduce partition columns: '20' (type: string)
               Statistics: Num rows: 275 Data size: 2921 Basic stats: COMPLETE Column stats: NONE
               value expressions: _col1 (type: string), _col3 (type: string)
       Reduce Operator Tree:
@@ -770,7 +770,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -782,7 +782,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -811,7 +811,7 @@ STAGE PLANS:
             Reduce Output Operator
               key expressions: '20' (type: string)
               sort order: +
-              Map-reduce partition columns: '' (type: string)
+              Map-reduce partition columns: '20' (type: string)
               Statistics: Num rows: 275 Data size: 2921 Basic stats: COMPLETE Column stats: NONE
               value expressions: _col1 (type: string), _col2 (type: string)
       Reduce Operator Tree:

Modified: hive/trunk/ql/src/test/results/clientpositive/constprog2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/constprog2.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/constprog2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/constprog2.q.out Fri Jan 16 16:45:13 2015
@@ -27,7 +27,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '86' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '86' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
           TableScan
@@ -41,7 +41,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '86' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '86' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -110,7 +110,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '86' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '86' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
           TableScan
@@ -124,7 +124,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '86' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '86' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/constprog_partitioner.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/constprog_partitioner.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/constprog_partitioner.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/constprog_partitioner.q.out Fri Jan 16 16:45:13 2015
@@ -27,7 +27,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '100' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '100' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
           TableScan
@@ -41,7 +41,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '100' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '100' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -84,3 +84,102 @@ POSTHOOK: Input: default@src
 100	101.0	val_100
 100	101.0	val_100
 100	101.0	val_100
+PREHOOK: query: EXPLAIN
+SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN
+SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Map Reduce
+      Map Operator Tree:
+          TableScan
+            alias: li
+            Statistics: Num rows: 100 Data size: 11999 Basic stats: COMPLETE Column stats: NONE
+            Filter Operator
+              predicate: ((l_linenumber = 1) and l_orderkey is not null) (type: boolean)
+              Statistics: Num rows: 25 Data size: 2999 Basic stats: COMPLETE Column stats: NONE
+              Select Operator
+                expressions: l_orderkey (type: int), l_partkey (type: int), l_suppkey (type: int), 1 (type: int)
+                outputColumnNames: _col0, _col1, _col2, _col3
+                Statistics: Num rows: 25 Data size: 2999 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col0 (type: int), _col3 (type: int)
+                  sort order: ++
+                  Map-reduce partition columns: _col0 (type: int), _col3 (type: int)
+                  Statistics: Num rows: 25 Data size: 2999 Basic stats: COMPLETE Column stats: NONE
+                  value expressions: _col1 (type: int), _col2 (type: int)
+          TableScan
+            alias: li
+            Statistics: Num rows: 100 Data size: 11999 Basic stats: COMPLETE Column stats: NONE
+            Filter Operator
+              predicate: (((l_shipmode = 'AIR') and l_orderkey is not null) and l_linenumber is not null) (type: boolean)
+              Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
+              Select Operator
+                expressions: l_orderkey (type: int), l_linenumber (type: int)
+                outputColumnNames: _col0, _col1
+                Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
+                Group By Operator
+                  keys: _col0 (type: int), _col1 (type: int)
+                  mode: hash
+                  outputColumnNames: _col0, _col1
+                  Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
+                  Reduce Output Operator
+                    key expressions: _col0 (type: int), _col1 (type: int)
+                    sort order: ++
+                    Map-reduce partition columns: _col0 (type: int), _col1 (type: int)
+                    Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
+      Reduce Operator Tree:
+        Join Operator
+          condition map:
+               Left Semi Join 0 to 1
+          keys:
+            0 _col0 (type: int), _col3 (type: int)
+            1 _col0 (type: int), _col1 (type: int)
+          outputColumnNames: _col1, _col2
+          Statistics: Num rows: 27 Data size: 3298 Basic stats: COMPLETE Column stats: NONE
+          Select Operator
+            expressions: _col1 (type: int), _col2 (type: int)
+            outputColumnNames: _col0, _col1
+            Statistics: Num rows: 27 Data size: 3298 Basic stats: COMPLETE Column stats: NONE
+            File Output Operator
+              compressed: false
+              Statistics: Num rows: 27 Data size: 3298 Basic stats: COMPLETE Column stats: NONE
+              table:
+                  input format: org.apache.hadoop.mapred.TextInputFormat
+                  output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
+                  serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+
+  Stage: Stage-0
+    Fetch Operator
+      limit: -1
+      Processor Tree:
+        ListSink
+
+PREHOOK: query: SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+PREHOOK: type: QUERY
+PREHOOK: Input: default@lineitem
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT l_partkey, l_suppkey
+FROM lineitem li
+WHERE li.l_linenumber = 1 AND
+ li.l_orderkey IN (SELECT l_orderkey FROM lineitem WHERE l_shipmode = 'AIR' AND l_linenumber = li.l_linenumber)
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@lineitem
+#### A masked pattern was here ####
+108570	8571
+4297	1798

Modified: hive/trunk/ql/src/test/results/clientpositive/identity_project_remove_skip.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/identity_project_remove_skip.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/identity_project_remove_skip.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/identity_project_remove_skip.q.out Fri Jan 16 16:45:13 2015
@@ -135,13 +135,13 @@ STAGE PLANS:
             Reduce Output Operator
               key expressions: '105' (type: string)
               sort order: +
-              Map-reduce partition columns: '' (type: string)
+              Map-reduce partition columns: '105' (type: string)
               Statistics: Num rows: 62 Data size: 658 Basic stats: COMPLETE Column stats: NONE
           TableScan
             Reduce Output Operator
               key expressions: '105' (type: string)
               sort order: +
-              Map-reduce partition columns: '' (type: string)
+              Map-reduce partition columns: '105' (type: string)
               Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/join_nullsafe.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/join_nullsafe.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/join_nullsafe.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/join_nullsafe.q.out Fri Jan 16 16:45:13 2015
@@ -1525,7 +1525,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: null (type: void)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: null (type: void)
                 Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: int)
           TableScan
@@ -1537,7 +1537,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: null (type: void)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: null (type: void)
                 Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
                 value expressions: key (type: int)
       Reduce Operator Tree:

Modified: hive/trunk/ql/src/test/results/clientpositive/ppd2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/ppd2.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/ppd2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/ppd2.q.out Fri Jan 16 16:45:13 2015
@@ -347,7 +347,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -359,7 +359,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/ppd_clusterby.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/ppd_clusterby.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/ppd_clusterby.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/ppd_clusterby.q.out Fri Jan 16 16:45:13 2015
@@ -25,7 +25,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '10' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '10' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -80,7 +80,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -92,7 +92,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -174,7 +174,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '10' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '10' (type: string)
                   Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col1 (type: string)
       Reduce Operator Tree:
@@ -229,7 +229,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
                 value expressions: value (type: string)
           TableScan
@@ -241,7 +241,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '20' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '20' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/ppd_join4.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/ppd_join4.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/ppd_join4.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/ppd_join4.q.out Fri Jan 16 16:45:13 2015
@@ -82,7 +82,7 @@ STAGE PLANS:
             Reduce Output Operator
               key expressions: 'a' (type: string)
               sort order: +
-              Map-reduce partition columns: '' (type: string)
+              Map-reduce partition columns: 'a' (type: string)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
           TableScan
             alias: t3
@@ -93,7 +93,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: 'a' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: 'a' (type: string)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/ppd_outer_join5.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/ppd_outer_join5.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/ppd_outer_join5.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/ppd_outer_join5.q.out Fri Jan 16 16:45:13 2015
@@ -73,9 +73,9 @@ STAGE PLANS:
               predicate: (id = 20) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Reduce Output Operator
-                key expressions: 20 (type: int)
+                key expressions: id (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: id (type: int)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 value expressions: key (type: string), value (type: string)
       Reduce Operator Tree:
@@ -126,9 +126,9 @@ STAGE PLANS:
               predicate: (id = 20) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Reduce Output Operator
-                key expressions: 20 (type: int)
+                key expressions: id (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: id (type: int)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 value expressions: key (type: string), value (type: string)
           TableScan
@@ -138,9 +138,9 @@ STAGE PLANS:
               predicate: (id = 20) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Reduce Output Operator
-                key expressions: 20 (type: int)
+                key expressions: id (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: id (type: int)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 value expressions: key (type: string), value (type: string)
           TableScan
@@ -164,10 +164,10 @@ STAGE PLANS:
             0 id (type: int)
             1 id (type: int)
             2 id (type: int)
-          outputColumnNames: _col1, _col2, _col7, _col8, _col12, _col13, _col14
+          outputColumnNames: _col0, _col1, _col2, _col7, _col8, _col12, _col13, _col14
           Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
           Select Operator
-            expressions: 20 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
+            expressions: _col0 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
             Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
             File Output Operator
@@ -203,9 +203,9 @@ STAGE PLANS:
               predicate: (id = 20) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Reduce Output Operator
-                key expressions: 20 (type: int)
+                key expressions: id (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: id (type: int)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 value expressions: key (type: string), value (type: string)
           TableScan
@@ -215,9 +215,9 @@ STAGE PLANS:
               predicate: (id = 20) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Reduce Output Operator
-                key expressions: 20 (type: int)
+                key expressions: id (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: id (type: int)
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 value expressions: key (type: string), value (type: string)
           TableScan
@@ -241,10 +241,10 @@ STAGE PLANS:
             0 id (type: int)
             1 id (type: int)
             2 id (type: int)
-          outputColumnNames: _col1, _col2, _col7, _col8, _col12, _col13, _col14
+          outputColumnNames: _col0, _col1, _col2, _col7, _col8, _col12, _col13, _col14
           Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
           Select Operator
-            expressions: 20 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
+            expressions: _col0 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
             Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
             File Output Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/ppd_union_view.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/ppd_union_view.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/ppd_union_view.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/ppd_union_view.q.out Fri Jan 16 16:45:13 2015
@@ -179,7 +179,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: keymap (type: string), '2011-10-13' (type: string)
                 sort order: ++
-                Map-reduce partition columns: keymap (type: string)
+                Map-reduce partition columns: keymap (type: string), '2011-10-13' (type: string)
                 Statistics: Num rows: 1 Data size: 14 Basic stats: COMPLETE Column stats: NONE
                 tag: 0
                 value expressions: value (type: string)
@@ -195,7 +195,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: keymap (type: string), '2011-10-13' (type: string)
                 sort order: ++
-                Map-reduce partition columns: keymap (type: string)
+                Map-reduce partition columns: keymap (type: string), '2011-10-13' (type: string)
                 Statistics: Num rows: 1 Data size: 12 Basic stats: COMPLETE Column stats: NONE
                 tag: 1
                 value expressions: key (type: string)

Modified: hive/trunk/ql/src/test/results/clientpositive/regex_col.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/regex_col.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/regex_col.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/regex_col.q.out Fri Jan 16 16:45:13 2015
@@ -174,7 +174,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '103' (type: string), _col2 (type: string), _col1 (type: string)
                   sort order: +++
-                  Map-reduce partition columns: _col2 (type: string), _col1 (type: string)
+                  Map-reduce partition columns: '103' (type: string), _col2 (type: string), _col1 (type: string)
                   Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
           TableScan
             alias: a
@@ -189,7 +189,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '103' (type: string), _col2 (type: string), _col1 (type: string)
                   sort order: +++
-                  Map-reduce partition columns: _col2 (type: string), _col1 (type: string)
+                  Map-reduce partition columns: '103' (type: string), _col2 (type: string), _col1 (type: string)
                   Statistics: Num rows: 1000 Data size: 10624 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/smb_mapjoin_25.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/smb_mapjoin_25.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/smb_mapjoin_25.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/smb_mapjoin_25.q.out Fri Jan 16 16:45:13 2015
@@ -71,7 +71,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: 5 (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: 5 (type: int)
                 Statistics: Num rows: 26 Data size: 104 Basic stats: COMPLETE Column stats: NONE
           TableScan
             alias: b
@@ -82,7 +82,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: 5 (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: 5 (type: int)
                 Statistics: Num rows: 25 Data size: 100 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator
@@ -154,7 +154,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: 5 (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: 5 (type: int)
                 Statistics: Num rows: 25 Data size: 100 Basic stats: COMPLETE Column stats: NONE
           TableScan
             alias: d
@@ -165,7 +165,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: 5 (type: int)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: 5 (type: int)
                 Statistics: Num rows: 27 Data size: 108 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/spark/ppd_join4.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/spark/ppd_join4.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/spark/ppd_join4.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/spark/ppd_join4.q.out Fri Jan 16 16:45:13 2015
@@ -81,7 +81,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 'a' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 'a' (type: string)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
         Reducer 2 
             Reduce Operator Tree:
@@ -90,7 +90,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: 'a' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: 'a' (type: string)
                   Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
         Reducer 3 
             Reduce Operator Tree:

Modified: hive/trunk/ql/src/test/results/clientpositive/spark/ppd_outer_join5.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/spark/ppd_outer_join5.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/spark/ppd_outer_join5.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/spark/ppd_outer_join5.q.out Fri Jan 16 16:45:13 2015
@@ -82,9 +82,9 @@ STAGE PLANS:
                     predicate: (id = 20) (type: boolean)
                     Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Reduce Output Operator
-                      key expressions: 20 (type: int)
+                      key expressions: id (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: id (type: int)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                       value expressions: key (type: string), value (type: string)
         Reducer 2 
@@ -141,9 +141,9 @@ STAGE PLANS:
                     predicate: (id = 20) (type: boolean)
                     Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Reduce Output Operator
-                      key expressions: 20 (type: int)
+                      key expressions: id (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: id (type: int)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                       value expressions: key (type: string), value (type: string)
         Map 3 
@@ -155,9 +155,9 @@ STAGE PLANS:
                     predicate: (id = 20) (type: boolean)
                     Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Reduce Output Operator
-                      key expressions: 20 (type: int)
+                      key expressions: id (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: id (type: int)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                       value expressions: key (type: string), value (type: string)
         Map 4 
@@ -184,10 +184,10 @@ STAGE PLANS:
                   0 id (type: int)
                   1 id (type: int)
                   2 id (type: int)
-                outputColumnNames: _col1, _col2, _col7, _col8, _col12, _col13, _col14
+                outputColumnNames: _col0, _col1, _col2, _col7, _col8, _col12, _col13, _col14
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Select Operator
-                  expressions: 20 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
+                  expressions: _col0 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
                   outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
                   Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                   File Output Operator
@@ -228,9 +228,9 @@ STAGE PLANS:
                     predicate: (id = 20) (type: boolean)
                     Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Reduce Output Operator
-                      key expressions: 20 (type: int)
+                      key expressions: id (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: id (type: int)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                       value expressions: key (type: string), value (type: string)
         Map 3 
@@ -242,9 +242,9 @@ STAGE PLANS:
                     predicate: (id = 20) (type: boolean)
                     Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Reduce Output Operator
-                      key expressions: 20 (type: int)
+                      key expressions: id (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: id (type: int)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                       value expressions: key (type: string), value (type: string)
         Map 4 
@@ -271,10 +271,10 @@ STAGE PLANS:
                   0 id (type: int)
                   1 id (type: int)
                   2 id (type: int)
-                outputColumnNames: _col1, _col2, _col7, _col8, _col12, _col13, _col14
+                outputColumnNames: _col0, _col1, _col2, _col7, _col8, _col12, _col13, _col14
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Select Operator
-                  expressions: 20 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
+                  expressions: _col0 (type: int), _col1 (type: string), _col2 (type: string), 20 (type: int), _col7 (type: string), _col8 (type: string), _col12 (type: int), _col13 (type: string), _col14 (type: string)
                   outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
                   Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                   File Output Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/spark/smb_mapjoin_25.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/spark/smb_mapjoin_25.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/spark/smb_mapjoin_25.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/spark/smb_mapjoin_25.q.out Fri Jan 16 16:45:13 2015
@@ -76,7 +76,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 5 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 5 (type: int)
                       Statistics: Num rows: 26 Data size: 104 Basic stats: COMPLETE Column stats: NONE
         Map 4 
             Map Operator Tree:
@@ -89,7 +89,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 5 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 5 (type: int)
                       Statistics: Num rows: 25 Data size: 100 Basic stats: COMPLETE Column stats: NONE
         Map 5 
             Map Operator Tree:
@@ -102,7 +102,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 5 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 5 (type: int)
                       Statistics: Num rows: 25 Data size: 100 Basic stats: COMPLETE Column stats: NONE
         Map 7 
             Map Operator Tree:
@@ -115,7 +115,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 5 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 5 (type: int)
                       Statistics: Num rows: 27 Data size: 108 Basic stats: COMPLETE Column stats: NONE
         Reducer 2 
             Reduce Operator Tree:

Modified: hive/trunk/ql/src/test/results/clientpositive/spark/vector_mapjoin_reduce.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/spark/vector_mapjoin_reduce.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/spark/vector_mapjoin_reduce.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/spark/vector_mapjoin_reduce.q.out Fri Jan 16 16:45:13 2015
@@ -223,7 +223,7 @@ STAGE PLANS:
                         Statistics: Num rows: 6 Data size: 719 Basic stats: COMPLETE Column stats: NONE
                         Spark HashTable Sink Operator
                           keys:
-                            0 _col1 (type: int), 1 (type: int)
+                            0 _col1 (type: int), _col4 (type: int)
                             1 _col0 (type: int), _col1 (type: int)
             Local Work:
               Map Reduce Local Work
@@ -267,7 +267,7 @@ STAGE PLANS:
                   keys:
                     0 _col0 (type: int)
                     1 l_partkey (type: int)
-                  outputColumnNames: _col0, _col1, _col3
+                  outputColumnNames: _col0, _col1, _col3, _col4
                   input vertices:
                     1 Map 3
                   Statistics: Num rows: 27 Data size: 3298 Basic stats: COMPLETE Column stats: NONE
@@ -275,7 +275,7 @@ STAGE PLANS:
                     condition map:
                          Left Semi Join 0 to 1
                     keys:
-                      0 _col1 (type: int), 1 (type: int)
+                      0 _col1 (type: int), _col4 (type: int)
                       1 _col0 (type: int), _col1 (type: int)
                     outputColumnNames: _col0, _col3
                     input vertices:

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning.q.out Fri Jan 16 16:45:13 2015
@@ -2576,7 +2576,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '11' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '11' (type: string)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Select Operator
                       expressions: '11' (type: string)
@@ -2605,7 +2605,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '11' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '11' (type: string)
                   Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
         Reducer 3 
             Reduce Operator Tree:
@@ -2715,7 +2715,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '13' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '13' (type: string)
                       Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
         Reducer 2 
             Reduce Operator Tree:
@@ -2729,7 +2729,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '13' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '13' (type: string)
                   Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
         Reducer 3 
             Reduce Operator Tree:
@@ -4694,7 +4694,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '11' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '11' (type: string)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Select Operator
                       expressions: '11' (type: string)

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning_2.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning_2.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning_2.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/dynamic_partition_pruning_2.q.out Fri Jan 16 16:45:13 2015
@@ -602,7 +602,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 1 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 1 (type: int)
                       Statistics: Num rows: 1 Data size: 5 Basic stats: COMPLETE Column stats: NONE
 
   Stage: Stage-0

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/join_nullsafe.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/join_nullsafe.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/join_nullsafe.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/join_nullsafe.q.out Fri Jan 16 16:45:13 2015
@@ -1578,7 +1578,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: null (type: void)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: null (type: void)
                       Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
                       value expressions: value (type: int)
         Map 3 
@@ -1592,7 +1592,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: null (type: void)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: null (type: void)
                       Statistics: Num rows: 1 Data size: 8 Basic stats: COMPLETE Column stats: NONE
                       value expressions: key (type: int)
         Reducer 2 

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/vector_decimal_mapjoin.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/vector_decimal_mapjoin.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/vector_decimal_mapjoin.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/vector_decimal_mapjoin.q.out Fri Jan 16 16:45:13 2015
@@ -82,7 +82,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: 6981 (type: int)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: 6981 (type: int)
                       Statistics: Num rows: 6144 Data size: 1082530 Basic stats: COMPLETE Column stats: NONE
                       value expressions: cdecimal2 (type: decimal(23,14))
             Execution mode: vectorized

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/vector_mapjoin_reduce.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/vector_mapjoin_reduce.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/vector_mapjoin_reduce.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/vector_mapjoin_reduce.q.out Fri Jan 16 16:45:13 2015
@@ -200,14 +200,14 @@ STAGE PLANS:
                     predicate: (((l_linenumber = 1) and l_orderkey is not null) and l_partkey is not null) (type: boolean)
                     Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
                     Select Operator
-                      expressions: l_orderkey (type: int), l_partkey (type: int), l_suppkey (type: int)
-                      outputColumnNames: _col0, _col1, _col2
+                      expressions: l_orderkey (type: int), l_partkey (type: int), l_suppkey (type: int), 1 (type: int)
+                      outputColumnNames: _col0, _col1, _col2, _col3
                       Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
                       Map Join Operator
                         condition map:
                              Left Semi Join 0 to 1
                         keys:
-                          0 _col0 (type: int), 1 (type: int)
+                          0 _col0 (type: int), _col3 (type: int)
                           1 _col0 (type: int), _col1 (type: int)
                         outputColumnNames: _col1, _col2
                         input vertices:

Modified: hive/trunk/ql/src/test/results/clientpositive/tez/vectorized_dynamic_partition_pruning.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/tez/vectorized_dynamic_partition_pruning.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/tez/vectorized_dynamic_partition_pruning.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/tez/vectorized_dynamic_partition_pruning.q.out Fri Jan 16 16:45:13 2015
@@ -2606,7 +2606,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '11' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '11' (type: string)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Select Operator
                       expressions: '11' (type: string)
@@ -2635,7 +2635,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '11' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '11' (type: string)
                   Statistics: Num rows: 1100 Data size: 11686 Basic stats: COMPLETE Column stats: NONE
         Reducer 3 
             Reduce Operator Tree:
@@ -2747,7 +2747,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '13' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '13' (type: string)
                       Statistics: Num rows: 1 Data size: 172 Basic stats: COMPLETE Column stats: NONE
         Reducer 2 
             Reduce Operator Tree:
@@ -2761,7 +2761,7 @@ STAGE PLANS:
                 Reduce Output Operator
                   key expressions: '13' (type: string)
                   sort order: +
-                  Map-reduce partition columns: '' (type: string)
+                  Map-reduce partition columns: '13' (type: string)
                   Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
         Reducer 3 
             Reduce Operator Tree:
@@ -4748,7 +4748,7 @@ STAGE PLANS:
                     Reduce Output Operator
                       key expressions: '11' (type: string)
                       sort order: +
-                      Map-reduce partition columns: '' (type: string)
+                      Map-reduce partition columns: '11' (type: string)
                       Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                     Select Operator
                       expressions: '11' (type: string)

Modified: hive/trunk/ql/src/test/results/clientpositive/union27.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/union27.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/union27.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/union27.q.out Fri Jan 16 16:45:13 2015
@@ -57,7 +57,7 @@ STAGE PLANS:
                   Reduce Output Operator
                     key expressions: '97' (type: string)
                     sort order: +
-                    Map-reduce partition columns: '' (type: string)
+                    Map-reduce partition columns: '97' (type: string)
                     Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
                     value expressions: _col1 (type: string)
           TableScan
@@ -75,7 +75,7 @@ STAGE PLANS:
                   Reduce Output Operator
                     key expressions: '97' (type: string)
                     sort order: +
-                    Map-reduce partition columns: '' (type: string)
+                    Map-reduce partition columns: '97' (type: string)
                     Statistics: Num rows: 500 Data size: 5312 Basic stats: COMPLETE Column stats: NONE
                     value expressions: _col1 (type: string)
           TableScan
@@ -87,7 +87,7 @@ STAGE PLANS:
               Reduce Output Operator
                 key expressions: '97' (type: string)
                 sort order: +
-                Map-reduce partition columns: '' (type: string)
+                Map-reduce partition columns: '97' (type: string)
                 Statistics: Num rows: 250 Data size: 2656 Basic stats: COMPLETE Column stats: NONE
       Reduce Operator Tree:
         Join Operator

Modified: hive/trunk/ql/src/test/results/clientpositive/vector_mapjoin_reduce.q.out
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/results/clientpositive/vector_mapjoin_reduce.q.out?rev=1652450&r1=1652449&r2=1652450&view=diff
==============================================================================
--- hive/trunk/ql/src/test/results/clientpositive/vector_mapjoin_reduce.q.out (original)
+++ hive/trunk/ql/src/test/results/clientpositive/vector_mapjoin_reduce.q.out Fri Jan 16 16:45:13 2015
@@ -475,7 +475,7 @@ STAGE PLANS:
                   Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
                   HashTable Sink Operator
                     keys:
-                      0 _col0 (type: int), 1 (type: int)
+                      0 _col0 (type: int), _col3 (type: int)
                       1 _col0 (type: int), _col1 (type: int)
 
   Stage: Stage-8
@@ -488,14 +488,14 @@ STAGE PLANS:
               predicate: (((l_linenumber = 1) and l_orderkey is not null) and l_partkey is not null) (type: boolean)
               Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
               Select Operator
-                expressions: l_orderkey (type: int), l_partkey (type: int), l_suppkey (type: int)
-                outputColumnNames: _col0, _col1, _col2
+                expressions: l_orderkey (type: int), l_partkey (type: int), l_suppkey (type: int), 1 (type: int)
+                outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 13 Data size: 1559 Basic stats: COMPLETE Column stats: NONE
                 Map Join Operator
                   condition map:
                        Left Semi Join 0 to 1
                   keys:
-                    0 _col0 (type: int), 1 (type: int)
+                    0 _col0 (type: int), _col3 (type: int)
                     1 _col0 (type: int), _col1 (type: int)
                   outputColumnNames: _col1, _col2
                   Statistics: Num rows: 14 Data size: 1714 Basic stats: COMPLETE Column stats: NONE