You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by gu...@apache.org on 2014/08/13 04:28:58 UTC

svn commit: r1617652 [5/7] - in /hive/branches/cbo: ./ ant/ ant/src/org/apache/hadoop/hive/ant/ beeline/ beeline/src/java/org/apache/hive/beeline/ beeline/src/main/resources/ cli/src/java/org/apache/hadoop/hive/cli/ common/src/java/org/apache/hadoop/hi...

Modified: hive/branches/cbo/ql/src/java/org/apache/hadoop/hive/ql/udf/generic/GenericUDAFAverage.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/java/org/apache/hadoop/hive/ql/udf/generic/GenericUDAFAverage.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/java/org/apache/hadoop/hive/ql/udf/generic/GenericUDAFAverage.java (original)
+++ hive/branches/cbo/ql/src/java/org/apache/hadoop/hive/ql/udf/generic/GenericUDAFAverage.java Wed Aug 13 02:28:54 2014
@@ -175,9 +175,11 @@ public class GenericUDAFAverage extends 
           if (ss.numPreceding != BoundarySpec.UNBOUNDED_AMOUNT
               && (ss.numRows - ss.numFollowing) >= (ss.numPreceding + 1)) {
             Object[] o = ss.intermediateVals.remove(0);
-            Double d = o == null ? 0.0 : (Double) o[0];
-            r = r == null ? null : r - d;
-            cnt = cnt - ((Long) o[1]);
+            if (o != null) {
+              Double d = (Double) o[0];
+              r = r == null ? null : r - d;
+              cnt = cnt - ((Long) o[1]);
+            }
           }
 
           return r == null ? null : new DoubleWritable(r / cnt);
@@ -303,9 +305,11 @@ public class GenericUDAFAverage extends 
           if (ss.numPreceding != BoundarySpec.UNBOUNDED_AMOUNT
               && (ss.numRows - ss.numFollowing) >= (ss.numPreceding + 1)) {
             Object[] o = ss.intermediateVals.remove(0);
-            HiveDecimal d = o == null ? HiveDecimal.ZERO : (HiveDecimal) o[0];
-            r = r == null ? null : r.subtract(d);
-            cnt = cnt - ((Long) o[1]);
+            if (o != null) {
+              HiveDecimal d = (HiveDecimal) o[0];
+              r = r == null ? null : r.subtract(d);
+              cnt = cnt - ((Long) o[1]);
+            }
           }
 
           return r == null ? null : new HiveDecimalWritable(

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizationContext.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizationContext.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizationContext.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizationContext.java Wed Aug 13 02:28:54 2014
@@ -1189,26 +1189,6 @@ public class TestVectorizationContext {
     children1.set(2,  col3Expr);
     ve = vc.getVectorExpression(exprDesc);
     assertTrue(ve instanceof IfExprStringScalarStringColumn);
-  }
-
-  @Test
-  public void testFoldConstantsForUnaryExpression() throws HiveException {
-    ExprNodeConstantDesc constDesc = new ExprNodeConstantDesc(new Integer(1));
-    GenericUDFToDecimal udf = new GenericUDFToDecimal();
-    udf.setTypeInfo(new DecimalTypeInfo(5, 2));
-    List<ExprNodeDesc> children = new ArrayList<ExprNodeDesc>();
-    children.add(constDesc);
-    ExprNodeGenericFuncDesc exprDesc = new ExprNodeGenericFuncDesc();
-    exprDesc.setGenericUDF(udf);
-    exprDesc.setChildren(children);
-    exprDesc.setTypeInfo(new DecimalTypeInfo(5, 2));
-    Map<String, Integer> columnMap = new HashMap<String, Integer>();
-    columnMap.put("col1", 1);
-    VectorizationContext vc = new VectorizationContext(columnMap, 1);
-    ExprNodeDesc constFoldNodeDesc = vc.foldConstantsForUnaryExpression(exprDesc); 
-    assertTrue(constFoldNodeDesc instanceof ExprNodeConstantDesc);
-    assertTrue(((HiveDecimal)
-      (((ExprNodeConstantDesc)constFoldNodeDesc).getValue())).toString().equals("1"));
   }  
 
 }

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizedRowBatchCtx.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizedRowBatchCtx.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizedRowBatchCtx.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/exec/vector/TestVectorizedRowBatchCtx.java Wed Aug 13 02:28:54 2014
@@ -49,6 +49,7 @@ import org.apache.hadoop.hive.serde2.obj
 import org.apache.hadoop.hive.serde2.objectinspector.StructField;
 import org.apache.hadoop.hive.serde2.objectinspector.StructObjectInspector;
 import org.apache.hadoop.io.BooleanWritable;
+import org.apache.hadoop.io.BytesWritable;
 import org.apache.hadoop.io.DataOutputBuffer;
 import org.apache.hadoop.io.FloatWritable;
 import org.apache.hadoop.io.IntWritable;
@@ -285,6 +286,15 @@ public class TestVectorizedRowBatchCtx {
             Assert.assertEquals(true, dcv.vector[i] == ((DoubleWritable) writableCol).get());
           }
             break;
+          case BINARY: {
+            BytesColumnVector bcv = (BytesColumnVector) batch.cols[j];
+              BytesWritable colBinary = (BytesWritable) writableCol;
+              BytesWritable batchBinary = (BytesWritable) bcv.getWritableObject(i);
+              byte[] a = colBinary.getBytes();
+              byte[] b = batchBinary.getBytes();
+              Assert.assertEquals(true, a.equals(b));
+          }
+            break;
           case STRING: {
             BytesColumnVector bcv = (BytesColumnVector) batch.cols[j];
             Text colText = (Text) writableCol;

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/metadata/TestHive.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/metadata/TestHive.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/metadata/TestHive.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/metadata/TestHive.java Wed Aug 13 02:28:54 2014
@@ -397,6 +397,7 @@ public class TestHive extends TestCase {
     try{
       // create a simple table
       String tableName = "table_for_testindex";
+      String qTableName = MetaStoreUtils.DEFAULT_DATABASE_NAME + "." + tableName;
       try {
         hm.dropTable(MetaStoreUtils.DEFAULT_DATABASE_NAME, tableName);
       } catch (HiveException e) {
@@ -431,6 +432,7 @@ public class TestHive extends TestCase {
       List<String> indexedCols = new ArrayList<String>();
       indexedCols.add("col1");
       String indexTableName = "index_on_table_for_testindex_table";
+      String qIndexTableName = MetaStoreUtils.DEFAULT_DATABASE_NAME + "." + indexTableName;
       boolean deferredRebuild = true;
       String inputFormat = SequenceFileInputFormat.class.getName();
       String outputFormat = SequenceFileOutputFormat.class.getName();
@@ -446,7 +448,7 @@ public class TestHive extends TestCase {
       Map<String, String> indexProps = null;
       Map<String, String> tableProps = null;
       Map<String, String> serdeProps = new HashMap<String, String>();
-      hm.createIndex(tableName, indexName, indexHandlerClass, indexedCols, indexTableName,
+      hm.createIndex(qTableName, indexName, indexHandlerClass, indexedCols, qIndexTableName,
           deferredRebuild, inputFormat, outputFormat, serde, storageHandler, location,
           indexProps, tableProps, serdeProps, collItemDelim, fieldDelim, fieldEscape, lineDelim,
           mapKeyDelim, indexComment);

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/TestQBCompact.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/TestQBCompact.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/TestQBCompact.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/TestQBCompact.java Wed Aug 13 02:28:54 2014
@@ -79,8 +79,7 @@ public class TestQBCompact {
     boolean sawException = false;
     AlterTableSimpleDesc desc = parseAndAnalyze("alter table foo compact 'major'");
     Assert.assertEquals("major", desc.getCompactionType());
-    Assert.assertEquals("foo", desc.getTableName());
-    Assert.assertEquals("default", desc.getDbName());
+    Assert.assertEquals("default.foo", desc.getTableName());
   }
 
   @Test
@@ -100,8 +99,7 @@ public class TestQBCompact {
     AlterTableSimpleDesc desc =
         parseAndAnalyze("alter table foo partition(ds = 'today') compact 'major'");
     Assert.assertEquals("major", desc.getCompactionType());
-    Assert.assertEquals("foo", desc.getTableName());
-    Assert.assertEquals("default", desc.getDbName());
+    Assert.assertEquals("default.foo", desc.getTableName());
     HashMap<String, String> parts = desc.getPartSpec();
     Assert.assertEquals(1, parts.size());
     Assert.assertEquals("today", parts.get("ds"));
@@ -112,8 +110,7 @@ public class TestQBCompact {
     AlterTableSimpleDesc desc =
         parseAndAnalyze("alter table foo partition(ds = 'today') compact 'minor'");
     Assert.assertEquals("minor", desc.getCompactionType());
-    Assert.assertEquals("foo", desc.getTableName());
-    Assert.assertEquals("default", desc.getDbName());
+    Assert.assertEquals("default.foo", desc.getTableName());
     HashMap<String, String> parts = desc.getPartSpec();
     Assert.assertEquals(1, parts.size());
     Assert.assertEquals("today", parts.get("ds"));

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/PrivilegesTestBase.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/PrivilegesTestBase.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/PrivilegesTestBase.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/PrivilegesTestBase.java Wed Aug 13 02:28:54 2014
@@ -31,6 +31,7 @@ import org.apache.hadoop.hive.ql.securit
 public class PrivilegesTestBase {
   protected static final String DB = "default";
   protected static final String TABLE = "table1";
+  protected static final String TABLE_QNAME = DB + "." + TABLE;
   protected static final String USER = "user1";
 
   public static void grantUserTable(String privStr, PrivilegeType privType, HiveConf conf, Hive db)
@@ -50,7 +51,7 @@ public class PrivilegesTestBase {
       Assert.assertEquals(USER, principal.getName());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
 
 }

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestHiveAuthorizationTaskFactory.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestHiveAuthorizationTaskFactory.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestHiveAuthorizationTaskFactory.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestHiveAuthorizationTaskFactory.java Wed Aug 13 02:28:54 2014
@@ -50,6 +50,7 @@ public class TestHiveAuthorizationTaskFa
   private static final String SELECT = "SELECT";
   private static final String DB = "default";
   private static final String TABLE = "table1";
+  private static final String TABLE_QNAME = DB + "." + TABLE;
   private static final String GROUP = "group1";
   private static final String ROLE = "role1";
   private static final String USER = "user1";
@@ -74,6 +75,7 @@ public class TestHiveAuthorizationTaskFa
     parseDriver = new ParseDriver();
     analyzer = new DDLSemanticAnalyzer(conf, db);
     Mockito.when(db.getTable(DB, TABLE, false)).thenReturn(table);
+    Mockito.when(db.getTable(TABLE_QNAME, false)).thenReturn(table);
     Mockito.when(db.getPartition(table, new HashMap<String, String>(), false))
       .thenReturn(partition);
     HadoopDefaultAuthenticator auth = new HadoopDefaultAuthenticator();
@@ -121,7 +123,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * GRANT ... ON TABLE ... TO ROLE ...
@@ -139,7 +141,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * GRANT ... ON TABLE ... TO GROUP ...
@@ -157,7 +159,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * REVOKE ... ON TABLE ... FROM USER ...
@@ -175,7 +177,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * REVOKE ... ON TABLE ... FROM ROLE ...
@@ -193,7 +195,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * REVOKE ... ON TABLE ... FROM GROUP ...
@@ -211,7 +213,7 @@ public class TestHiveAuthorizationTaskFa
       Assert.assertEquals(Privilege.SELECT, privilege.getPrivilege());
     }
     Assert.assertTrue("Expected table", grantDesc.getPrivilegeSubjectDesc().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getPrivilegeSubjectDesc().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getPrivilegeSubjectDesc().getObject());
   }
   /**
    * GRANT ROLE ... TO USER ...
@@ -380,7 +382,7 @@ public class TestHiveAuthorizationTaskFa
     Assert.assertEquals(PrincipalType.USER, grantDesc.getPrincipalDesc().getType());
     Assert.assertEquals(USER, grantDesc.getPrincipalDesc().getName());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getHiveObj().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getHiveObj().getObject());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
   }
   /**
@@ -394,7 +396,7 @@ public class TestHiveAuthorizationTaskFa
     Assert.assertEquals(PrincipalType.ROLE, grantDesc.getPrincipalDesc().getType());
     Assert.assertEquals(ROLE, grantDesc.getPrincipalDesc().getName());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getHiveObj().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getHiveObj().getObject());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
   }
   /**
@@ -408,7 +410,7 @@ public class TestHiveAuthorizationTaskFa
     Assert.assertEquals(PrincipalType.GROUP, grantDesc.getPrincipalDesc().getType());
     Assert.assertEquals(GROUP, grantDesc.getPrincipalDesc().getName());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
-    Assert.assertEquals(TABLE, grantDesc.getHiveObj().getObject());
+    Assert.assertEquals(TABLE_QNAME, grantDesc.getHiveObj().getObject());
     Assert.assertTrue("Expected table", grantDesc.getHiveObj().getTable());
   }
 

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV1.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV1.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV1.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV1.java Wed Aug 13 02:28:54 2014
@@ -46,6 +46,7 @@ public class TestPrivilegesV1 extends Pr
     partition = new Partition(table);
     SessionState.start(conf);
     Mockito.when(db.getTable(DB, TABLE, false)).thenReturn(table);
+    Mockito.when(db.getTable(TABLE_QNAME, false)).thenReturn(table);
     Mockito.when(db.getPartition(table, new HashMap<String, String>(), false))
     .thenReturn(partition);
   }

Modified: hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV2.java
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV2.java?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV2.java (original)
+++ hive/branches/cbo/ql/src/test/org/apache/hadoop/hive/ql/parse/authorization/TestPrivilegesV2.java Wed Aug 13 02:28:54 2014
@@ -47,6 +47,7 @@ public class TestPrivilegesV2 extends Pr
     table = new Table(DB, TABLE);
     SessionState.start(conf);
     Mockito.when(db.getTable(DB, TABLE, false)).thenReturn(table);
+    Mockito.when(db.getTable(TABLE_QNAME, false)).thenReturn(table);
     Mockito.when(db.getPartition(table, new HashMap<String, String>(), false))
     .thenReturn(partition);
   }

Modified: hive/branches/cbo/ql/src/test/queries/clientpositive/having.q
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/queries/clientpositive/having.q?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/queries/clientpositive/having.q (original)
+++ hive/branches/cbo/ql/src/test/queries/clientpositive/having.q Wed Aug 13 02:28:54 2014
@@ -12,3 +12,6 @@ SELECT key FROM src where key > 300 GROU
 
 EXPLAIN SELECT key, max(value) FROM src GROUP BY key HAVING max(value) > "val_255";
 SELECT key, max(value) FROM src GROUP BY key HAVING max(value) > "val_255";
+
+EXPLAIN SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4;
+SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4;
\ No newline at end of file

Modified: hive/branches/cbo/ql/src/test/queries/clientpositive/mapjoin_mapjoin.q
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/queries/clientpositive/mapjoin_mapjoin.q?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/queries/clientpositive/mapjoin_mapjoin.q (original)
+++ hive/branches/cbo/ql/src/test/queries/clientpositive/mapjoin_mapjoin.q Wed Aug 13 02:28:54 2014
@@ -4,7 +4,7 @@ set hive.auto.convert.join.noconditional
 
 -- Since the inputs are small, it should be automatically converted to mapjoin
 
-explain select srcpart.key from srcpart join src on (srcpart.value=src.value) join src1 on (srcpart.key=src1.key);
+explain extended select srcpart.key from srcpart join src on (srcpart.value=src.value) join src1 on (srcpart.key=src1.key);
 
 explain
 select srcpart.key from srcpart join src on (srcpart.value=src.value) join src1 on (srcpart.key=src1.key) where srcpart.value > 'val_450';

Modified: hive/branches/cbo/ql/src/test/queries/clientpositive/vector_coalesce.q
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/queries/clientpositive/vector_coalesce.q?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/queries/clientpositive/vector_coalesce.q (original)
+++ hive/branches/cbo/ql/src/test/queries/clientpositive/vector_coalesce.q Wed Aug 13 02:28:54 2014
@@ -7,6 +7,8 @@ SELECT cdouble, cstring1, cint, cfloat, 
 FROM alltypesorc
 WHERE (cdouble IS NULL) LIMIT 10;
 
+SET hive.optimize.constant.propagation=false;
+   
 EXPLAIN SELECT ctinyint, cdouble, cint, coalesce(ctinyint+10, (cdouble+log2(cint)), 0) 
 FROM alltypesorc
 WHERE (ctinyint IS NULL) LIMIT 10;
@@ -15,6 +17,8 @@ SELECT ctinyint, cdouble, cint, coalesce
 FROM alltypesorc
 WHERE (ctinyint IS NULL) LIMIT 10;
 
+SET hive.optimize.constant.propagation=true;
+
 EXPLAIN SELECT cfloat, cbigint, coalesce(cfloat, cbigint, 0) 
 FROM alltypesorc
 WHERE (cfloat IS NULL AND cbigint IS NULL) LIMIT 10;

Modified: hive/branches/cbo/ql/src/test/queries/clientpositive/vectorized_date_funcs.q
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/queries/clientpositive/vectorized_date_funcs.q?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/queries/clientpositive/vectorized_date_funcs.q (original)
+++ hive/branches/cbo/ql/src/test/queries/clientpositive/vectorized_date_funcs.q Wed Aug 13 02:28:54 2014
@@ -120,3 +120,6 @@ SELECT 
   datediff(fl_date, date_sub(fl_date, 2)),
   datediff(date_add(fl_date, 2), date_sub(fl_date, 2)) 
 FROM date_udf_flight_orc LIMIT 10;
+
+-- Test extracting the date part of expression that includes time
+SELECT to_date('2009-07-30 04:17:52') FROM date_udf_flight_orc LIMIT 1;
\ No newline at end of file

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/alter_concatenate_indexed_table.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/alter_concatenate_indexed_table.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/alter_concatenate_indexed_table.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/alter_concatenate_indexed_table.q.out Wed Aug 13 02:28:54 2014
@@ -74,4 +74,4 @@ PREHOOK: type: SHOWINDEXES
 POSTHOOK: query: show indexes on src_rc_concatenate_test
 POSTHOOK: type: SHOWINDEXES
 src_rc_concatenate_test_index	src_rc_concatenate_test	key                 	default__src_rc_concatenate_test_src_rc_concatenate_test_index__	compact             	
-FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: can not do merge because source table src_rc_concatenate_test is indexed.
+FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: can not do merge because source table default.src_rc_concatenate_test is indexed.

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/alter_view_failure6.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/alter_view_failure6.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/alter_view_failure6.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/alter_view_failure6.q.out Wed Aug 13 02:28:54 2014
@@ -15,5 +15,5 @@ SELECT hr,key FROM srcpart
 POSTHOOK: type: CREATEVIEW
 POSTHOOK: Input: default@srcpart
 POSTHOOK: Output: default@xxx7
-FAILED: SemanticException [Error 10041]: No partition predicate found for Alias "xxx7:srcpart" Table "srcpart"
+FAILED: SemanticException [Error 10041]: No partition predicate found for Alias "default.xxx7:srcpart" Table "srcpart"
 FAILED: SemanticException [Error 10056]: The query does not reference any valid partition. To run this query, set hive.mapred.mode=nonstrict

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_1.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_1.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_1.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_1.q.out Wed Aug 13 02:28:54 2014
@@ -10,4 +10,4 @@ PREHOOK: type: CREATEINDEX
 POSTHOOK: query: CREATE INDEX src_index_merge_test ON TABLE src2(key) as 'COMPACT' WITH DEFERRED REBUILD
 POSTHOOK: type: CREATEINDEX
 POSTHOOK: Output: default@default__src2_src_index_merge_test__
-FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: can not do merge because source table src2 is indexed.
+FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: can not do merge because source table default.src2 is indexed.

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_2.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_2.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_2.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/merge_negative_2.q.out Wed Aug 13 02:28:54 2014
@@ -15,4 +15,4 @@ POSTHOOK: Input: default@src
 POSTHOOK: Output: default@srcpart2@ds=2011
 POSTHOOK: Lineage: srcpart2 PARTITION(ds=2011).key EXPRESSION [(src)src.FieldSchema(name:key, type:string, comment:default), ]
 POSTHOOK: Lineage: srcpart2 PARTITION(ds=2011).value SIMPLE [(src)src.FieldSchema(name:value, type:string, comment:default), ]
-FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: source table srcpart2 is partitioned but no partition desc found.
+FAILED: SemanticException org.apache.hadoop.hive.ql.parse.SemanticException: source table default.srcpart2 is partitioned but no partition desc found.

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/show_columns3.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/show_columns3.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/show_columns3.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/show_columns3.q.out Wed Aug 13 02:28:54 2014
@@ -17,4 +17,4 @@ PREHOOK: query: use default
 PREHOOK: type: SWITCHDATABASE
 POSTHOOK: query: use default
 POSTHOOK: type: SWITCHDATABASE
-FAILED: SemanticException [Error 10001]: Table not found test_db.foo
+FAILED: SemanticException Duplicates declaration for database name

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/show_tableproperties1.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/show_tableproperties1.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/show_tableproperties1.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/show_tableproperties1.q.out Wed Aug 13 02:28:54 2014
@@ -1 +1 @@
-FAILED: SemanticException [Error 10001]: Table not found NonExistentTable
+FAILED: SemanticException [Error 10001]: Table not found default.NonExistentTable

Modified: hive/branches/cbo/ql/src/test/results/clientnegative/temp_table_index.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientnegative/temp_table_index.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientnegative/temp_table_index.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientnegative/temp_table_index.q.out Wed Aug 13 02:28:54 2014
@@ -7,4 +7,4 @@ POSTHOOK: Output: database:default
 POSTHOOK: Output: default@tmp1
 PREHOOK: query: create index tmp1_idx on table tmp1 (c1) as 'COMPACT' with deferred rebuild
 PREHOOK: type: CREATEINDEX
-FAILED: Execution Error, return code 1 from org.apache.hadoop.hive.ql.exec.DDLTask. org.apache.hadoop.hive.ql.metadata.HiveException: tableName=tmp1 is a TEMPORARY TABLE. Index on TEMPORARY TABLE is not supported.
+FAILED: Execution Error, return code 1 from org.apache.hadoop.hive.ql.exec.DDLTask. org.apache.hadoop.hive.ql.metadata.HiveException: tableName=default.tmp1 is a TEMPORARY TABLE. Index on TEMPORARY TABLE is not supported.

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/annotate_stats_join.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/annotate_stats_join.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/annotate_stats_join.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/annotate_stats_join.q.out Wed Aug 13 02:28:54 2014
@@ -551,14 +551,14 @@ STAGE PLANS:
             1 {KEY.reducesinkkey0} {VALUE._col0}
             2 {VALUE._col0} {KEY.reducesinkkey0} {VALUE._col1} {VALUE._col2}
           outputColumnNames: _col0, _col1, _col2, _col5, _col6, _col9, _col10, _col11, _col12
-          Statistics: Num rows: 47 Data size: 13900 Basic stats: COMPLETE Column stats: COMPLETE
+          Statistics: Num rows: 47 Data size: 13912 Basic stats: COMPLETE Column stats: COMPLETE
           Select Operator
             expressions: _col0 (type: string), _col1 (type: int), _col2 (type: int), _col5 (type: int), _col6 (type: string), _col9 (type: string), _col10 (type: int), _col11 (type: bigint), _col12 (type: int)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
-            Statistics: Num rows: 47 Data size: 13900 Basic stats: COMPLETE Column stats: COMPLETE
+            Statistics: Num rows: 47 Data size: 13912 Basic stats: COMPLETE Column stats: COMPLETE
             File Output Operator
               compressed: false
-              Statistics: Num rows: 47 Data size: 13900 Basic stats: COMPLETE Column stats: COMPLETE
+              Statistics: Num rows: 47 Data size: 13912 Basic stats: COMPLETE Column stats: COMPLETE
               table:
                   input format: org.apache.hadoop.mapred.TextInputFormat
                   output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
@@ -631,14 +631,14 @@ STAGE PLANS:
             1 {KEY.reducesinkkey0} {KEY.reducesinkkey1}
             2 {KEY.reducesinkkey1} {KEY.reducesinkkey0} {VALUE._col0} {VALUE._col1}
           outputColumnNames: _col0, _col1, _col2, _col5, _col6, _col9, _col10, _col11, _col12
-          Statistics: Num rows: 1 Data size: 284 Basic stats: COMPLETE Column stats: COMPLETE
+          Statistics: Num rows: 1 Data size: 296 Basic stats: COMPLETE Column stats: COMPLETE
           Select Operator
             expressions: _col0 (type: string), _col1 (type: int), _col2 (type: int), _col5 (type: int), _col6 (type: string), _col9 (type: string), _col10 (type: int), _col11 (type: bigint), _col12 (type: int)
             outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8
-            Statistics: Num rows: 1 Data size: 284 Basic stats: COMPLETE Column stats: COMPLETE
+            Statistics: Num rows: 1 Data size: 296 Basic stats: COMPLETE Column stats: COMPLETE
             File Output Operator
               compressed: false
-              Statistics: Num rows: 1 Data size: 284 Basic stats: COMPLETE Column stats: COMPLETE
+              Statistics: Num rows: 1 Data size: 296 Basic stats: COMPLETE Column stats: COMPLETE
               table:
                   input format: org.apache.hadoop.mapred.TextInputFormat
                   output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/drop_multi_partitions.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/drop_multi_partitions.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/drop_multi_partitions.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/drop_multi_partitions.q.out Wed Aug 13 02:28:54 2014
@@ -42,7 +42,8 @@ POSTHOOK: type: ALTERTABLE_DROPPARTS
 ABSTRACT SYNTAX TREE:
   
 TOK_ALTERTABLE_DROPPARTS
-   mp
+   TOK_TABNAME
+      mp
    TOK_PARTSPEC
       TOK_PARTVAL
          b
@@ -57,7 +58,7 @@ STAGE PLANS:
   Stage: Stage-0
       Drop Table Operator:
         Drop Table
-          table: mp
+          table: default.mp
 
 PREHOOK: query: alter table mp drop partition (b='1')
 PREHOOK: type: ALTERTABLE_DROPPARTS

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/having.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/having.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/having.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/having.q.out Wed Aug 13 02:28:54 2014
@@ -1177,3 +1177,80 @@ POSTHOOK: Input: default@src
 96	val_96
 97	val_97
 98	val_98
+PREHOOK: query: EXPLAIN SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+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: src
+            Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+            Select Operator
+              expressions: key (type: string), value (type: string)
+              outputColumnNames: key, value
+              Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+              Group By Operator
+                aggregations: count(value)
+                keys: key (type: string)
+                mode: hash
+                outputColumnNames: _col0, _col1
+                Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                Reduce Output Operator
+                  key expressions: _col0 (type: string)
+                  sort order: +
+                  Map-reduce partition columns: _col0 (type: string)
+                  Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                  value expressions: _col1 (type: bigint)
+      Reduce Operator Tree:
+        Group By Operator
+          aggregations: count(VALUE._col0)
+          keys: KEY._col0 (type: string)
+          mode: mergepartial
+          outputColumnNames: _col0, _col1
+          Statistics: Num rows: 14 Data size: 2805 Basic stats: COMPLETE Column stats: NONE
+          Filter Operator
+            predicate: (_col1 >= 4) (type: boolean)
+            Statistics: Num rows: 4 Data size: 801 Basic stats: COMPLETE Column stats: NONE
+            Select Operator
+              expressions: _col0 (type: string), _col1 (type: bigint)
+              outputColumnNames: _col0, _col1
+              Statistics: Num rows: 4 Data size: 801 Basic stats: COMPLETE Column stats: NONE
+              File Output Operator
+                compressed: false
+                Statistics: Num rows: 4 Data size: 801 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 key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+PREHOOK: type: QUERY
+PREHOOK: Input: default@src
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@src
+#### A masked pattern was here ####
+138	4
+169	4
+230	5
+277	4
+348	5
+401	5
+406	4
+468	4
+469	5
+489	4

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/input3.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/input3.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/input3.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/input3.q.out Wed Aug 13 02:28:54 2014
@@ -59,7 +59,7 @@ STAGE PLANS:
         Alter Table
           type: add columns
           new columns: x double
-          old name: TEST3b
+          old name: default.TEST3b
 
 PREHOOK: query: ALTER TABLE TEST3b ADD COLUMNS (X DOUBLE)
 PREHOOK: type: ALTERTABLE_ADDCOLS
@@ -93,8 +93,8 @@ STAGE PLANS:
       Alter Table Operator:
         Alter Table
           type: rename
-          new name: TEST3c
-          old name: TEST3b
+          new name: default.TEST3c
+          old name: default.TEST3b
 
 PREHOOK: query: ALTER TABLE TEST3b RENAME TO TEST3c
 PREHOOK: type: ALTERTABLE_RENAME
@@ -145,7 +145,7 @@ STAGE PLANS:
         Alter Table
           type: replace columns
           new columns: r1 int, r2 double
-          old name: TEST3c
+          old name: default.TEST3c
 
 PREHOOK: query: ALTER TABLE TEST3c REPLACE COLUMNS (R1 INT, R2 DOUBLE)
 PREHOOK: type: ALTERTABLE_REPLACECOLS

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/insert2_overwrite_partitions.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/insert2_overwrite_partitions.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/insert2_overwrite_partitions.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/insert2_overwrite_partitions.q.out Wed Aug 13 02:28:54 2014
@@ -213,13 +213,19 @@ POSTHOOK: Input: db2@destintable@ds=2011
 97	val_97
 PREHOOK: query: drop table db2.destinTable
 PREHOOK: type: DROPTABLE
+PREHOOK: Input: db2@destintable
+PREHOOK: Output: db2@destintable
 POSTHOOK: query: drop table db2.destinTable
 POSTHOOK: type: DROPTABLE
+POSTHOOK: Input: db2@destintable
 POSTHOOK: Output: db2@destintable
 PREHOOK: query: drop table db1.sourceTable
 PREHOOK: type: DROPTABLE
+PREHOOK: Input: db1@sourcetable
+PREHOOK: Output: db1@sourcetable
 POSTHOOK: query: drop table db1.sourceTable
 POSTHOOK: type: DROPTABLE
+POSTHOOK: Input: db1@sourcetable
 POSTHOOK: Output: db1@sourcetable
 PREHOOK: query: DROP DATABASE db1
 PREHOOK: type: DROPDATABASE

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/mapjoin_mapjoin.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/mapjoin_mapjoin.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
Files hive/branches/cbo/ql/src/test/results/clientpositive/mapjoin_mapjoin.q.out (original) and hive/branches/cbo/ql/src/test/results/clientpositive/mapjoin_mapjoin.q.out Wed Aug 13 02:28:54 2014 differ

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/ql_rewrite_gbtoidx.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/ql_rewrite_gbtoidx.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/ql_rewrite_gbtoidx.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/ql_rewrite_gbtoidx.q.out Wed Aug 13 02:28:54 2014
@@ -474,9 +474,11 @@ STAGE PLANS:
               key expressions: _col0 (type: int), _col1 (type: int)
               sort order: ++
               Statistics: Num rows: 60 Data size: 6049 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col0 (type: int), _col1 (type: int), _col2 (type: bigint)
+              value expressions: _col2 (type: bigint)
       Reduce Operator Tree:
-        Extract
+        Select Operator
+          expressions: KEY.reducesinkkey0 (type: int), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: bigint)
+          outputColumnNames: _col0, _col1, _col2
           Statistics: Num rows: 60 Data size: 6049 Basic stats: COMPLETE Column stats: NONE
           File Output Operator
             compressed: false
@@ -621,9 +623,11 @@ STAGE PLANS:
               key expressions: _col0 (type: int), _col1 (type: int)
               sort order: ++
               Statistics: Num rows: 47 Data size: 4291 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col0 (type: int), _col1 (type: int), _col2 (type: bigint)
+              value expressions: _col2 (type: bigint)
       Reduce Operator Tree:
-        Extract
+        Select Operator
+          expressions: KEY.reducesinkkey0 (type: int), KEY.reducesinkkey1 (type: int), VALUE._col0 (type: bigint)
+          outputColumnNames: _col0, _col1, _col2
           Statistics: Num rows: 47 Data size: 4291 Basic stats: COMPLETE Column stats: NONE
           File Output Operator
             compressed: false
@@ -765,24 +769,27 @@ STAGE PLANS:
                   keys: year(l_shipdate) (type: int), month(l_shipdate) (type: int)
                   mode: hash
                   outputColumnNames: _col0, _col1, _col2
-                  Statistics: Num rows: 47 Data size: 4291 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: 47 Data size: 4291 Basic stats: COMPLETE Column stats: NONE
-                    value expressions: _col2 (type: bigint)
+                  Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: _col1 is not null (type: boolean)
+                    Statistics: Num rows: 12 Data size: 1095 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: 12 Data size: 1095 Basic stats: COMPLETE Column stats: NONE
+                      value expressions: _col2 (type: bigint)
       Reduce Operator Tree:
         Group By Operator
           aggregations: sum(VALUE._col0)
           keys: KEY._col0 (type: int), KEY._col1 (type: int)
           mode: mergepartial
           outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+          Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: _col1 (type: int), _col2 (type: bigint)
             outputColumnNames: _col1, _col2
-            Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+            Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
             File Output Operator
               compressed: false
               table:
@@ -798,31 +805,31 @@ STAGE PLANS:
               key expressions: _col1 (type: int)
               sort order: +
               Map-reduce partition columns: _col1 (type: int)
-              Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: int), _col2 (type: bigint)
+              Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
+              value expressions: _col2 (type: bigint)
           TableScan
             Reduce Output Operator
               key expressions: _col1 (type: int)
               sort order: +
               Map-reduce partition columns: _col1 (type: int)
-              Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col1 (type: int), _col2 (type: bigint)
+              Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
+              value expressions: _col2 (type: bigint)
       Reduce Operator Tree:
         Join Operator
           condition map:
                Inner Join 0 to 1
           condition expressions:
-            0 {VALUE._col1} {VALUE._col2}
-            1 {VALUE._col1} {VALUE._col2}
+            0 {KEY.reducesinkkey0} {VALUE._col1}
+            1 {KEY.reducesinkkey0} {VALUE._col1}
           outputColumnNames: _col1, _col2, _col4, _col5
-          Statistics: Num rows: 25 Data size: 2308 Basic stats: COMPLETE Column stats: NONE
+          Statistics: Num rows: 6 Data size: 601 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: _col1 (type: int), _col4 (type: int), ((_col5 - _col2) / _col2) (type: double)
             outputColumnNames: _col0, _col1, _col2
-            Statistics: Num rows: 25 Data size: 2308 Basic stats: COMPLETE Column stats: NONE
+            Statistics: Num rows: 6 Data size: 601 Basic stats: COMPLETE Column stats: NONE
             File Output Operator
               compressed: false
-              Statistics: Num rows: 25 Data size: 2308 Basic stats: COMPLETE Column stats: NONE
+              Statistics: Num rows: 6 Data size: 601 Basic stats: COMPLETE Column stats: NONE
               table:
                   input format: org.apache.hadoop.mapred.TextInputFormat
                   output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
@@ -846,24 +853,27 @@ STAGE PLANS:
                   keys: year(l_shipdate) (type: int), month(l_shipdate) (type: int)
                   mode: hash
                   outputColumnNames: _col0, _col1, _col2
-                  Statistics: Num rows: 47 Data size: 4291 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: 47 Data size: 4291 Basic stats: COMPLETE Column stats: NONE
-                    value expressions: _col2 (type: bigint)
+                  Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+                  Filter Operator
+                    predicate: _col1 is not null (type: boolean)
+                    Statistics: Num rows: 12 Data size: 1095 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: 12 Data size: 1095 Basic stats: COMPLETE Column stats: NONE
+                      value expressions: _col2 (type: bigint)
       Reduce Operator Tree:
         Group By Operator
           aggregations: sum(VALUE._col0)
           keys: KEY._col0 (type: int), KEY._col1 (type: int)
           mode: mergepartial
           outputColumnNames: _col0, _col1, _col2
-          Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+          Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
           Select Operator
             expressions: _col1 (type: int), _col2 (type: bigint)
             outputColumnNames: _col1, _col2
-            Statistics: Num rows: 23 Data size: 2099 Basic stats: COMPLETE Column stats: NONE
+            Statistics: Num rows: 6 Data size: 547 Basic stats: COMPLETE Column stats: NONE
             File Output Operator
               compressed: false
               table:
@@ -890,16 +900,16 @@ select l_shipdate, l_orderkey as cnt
 from lineitem) dummy
 POSTHOOK: type: QUERY
 STAGE DEPENDENCIES:
-  Stage-1 is a root stage
-  Stage-2 depends on stages: Stage-1
+  Stage-3 is a root stage
+  Stage-2 depends on stages: Stage-3
   Stage-0 depends on stages: Stage-2
 
 STAGE PLANS:
-  Stage: Stage-1
+  Stage: Stage-3
     Map Reduce
       Map Operator Tree:
           TableScan
-            alias: null-subquery1:default__lineitem_lineitem_lshipdate_idx__
+            alias: null-subquery1:dummy-subquery1:default__lineitem_lineitem_lshipdate_idx__
             Statistics: Num rows: 95 Data size: 8675 Basic stats: COMPLETE Column stats: NONE
             Select Operator
               expressions: l_shipdate (type: string), _count_of_l_shipdate (type: bigint)
@@ -939,20 +949,6 @@ STAGE PLANS:
     Map Reduce
       Map Operator Tree:
           TableScan
-            Union
-              Statistics: Num rows: 163 Data size: 16390 Basic stats: COMPLETE Column stats: NONE
-              Select Operator
-                expressions: _col0 (type: string), _col1 (type: bigint)
-                outputColumnNames: _col0, _col1
-                Statistics: Num rows: 163 Data size: 16390 Basic stats: COMPLETE Column stats: NONE
-                File Output Operator
-                  compressed: false
-                  Statistics: Num rows: 163 Data size: 16390 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
-          TableScan
             alias: lineitem
             Statistics: Num rows: 116 Data size: 12099 Basic stats: COMPLETE Column stats: NONE
             Select Operator
@@ -972,6 +968,20 @@ STAGE PLANS:
                         input format: org.apache.hadoop.mapred.TextInputFormat
                         output format: org.apache.hadoop.hive.ql.io.HiveIgnoreKeyTextOutputFormat
                         serde: org.apache.hadoop.hive.serde2.lazy.LazySimpleSerDe
+          TableScan
+            Union
+              Statistics: Num rows: 163 Data size: 16390 Basic stats: COMPLETE Column stats: NONE
+              Select Operator
+                expressions: _col0 (type: string), _col1 (type: bigint)
+                outputColumnNames: _col0, _col1
+                Statistics: Num rows: 163 Data size: 16390 Basic stats: COMPLETE Column stats: NONE
+                File Output Operator
+                  compressed: false
+                  Statistics: Num rows: 163 Data size: 16390 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
@@ -1016,17 +1026,17 @@ STAGE PLANS:
     Map Reduce
       Map Operator Tree:
           TableScan
-            alias: default__tbl_tbl_key_idx__
+            alias: tbl
             Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
             Filter Operator
               predicate: (key = 1) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int), _count_of_key (type: bigint)
-                outputColumnNames: key, _count_of_key
+                expressions: 1 (type: int)
+                outputColumnNames: key
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
-                  aggregations: sum(_count_of_key)
+                  aggregations: count(key)
                   keys: key (type: int)
                   mode: hash
                   outputColumnNames: _col0, _col1
@@ -1039,7 +1049,7 @@ STAGE PLANS:
                     value expressions: _col1 (type: bigint)
       Reduce Operator Tree:
         Group By Operator
-          aggregations: sum(VALUE._col0)
+          aggregations: count(VALUE._col0)
           keys: KEY._col0 (type: int)
           mode: mergepartial
           outputColumnNames: _col0, _col1
@@ -1345,7 +1355,7 @@ STAGE PLANS:
               predicate: (key = 3) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int)
+                expressions: 3 (type: int)
                 outputColumnNames: key
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
@@ -1563,7 +1573,7 @@ STAGE PLANS:
               predicate: (value = 1) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int), value (type: int)
+                expressions: key (type: int), 1 (type: int)
                 outputColumnNames: key, value
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
@@ -1831,7 +1841,7 @@ STAGE PLANS:
               predicate: (value = 2) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int), value (type: int)
+                expressions: key (type: int), 2 (type: int)
                 outputColumnNames: key, value
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
@@ -1887,7 +1897,7 @@ STAGE PLANS:
               predicate: ((value = 2) and (key = 3)) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int), value (type: int)
+                expressions: 3 (type: int), 2 (type: int)
                 outputColumnNames: key, value
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
@@ -2108,7 +2118,7 @@ STAGE PLANS:
               predicate: (value = 2) (type: boolean)
               Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
               Select Operator
-                expressions: key (type: int), value (type: int)
+                expressions: key (type: int), 2 (type: int)
                 outputColumnNames: key, value
                 Statistics: Num rows: 0 Data size: 0 Basic stats: NONE Column stats: NONE
                 Group By Operator
@@ -2489,9 +2499,11 @@ STAGE PLANS:
               key expressions: _col0 (type: int)
               sort order: +
               Statistics: Num rows: 8 Data size: 32 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col0 (type: int), _col1 (type: bigint)
+              value expressions: _col1 (type: bigint)
       Reduce Operator Tree:
-        Extract
+        Select Operator
+          expressions: KEY.reducesinkkey0 (type: int), VALUE._col0 (type: bigint)
+          outputColumnNames: _col0, _col1
           Statistics: Num rows: 8 Data size: 32 Basic stats: COMPLETE Column stats: NONE
           File Output Operator
             compressed: false
@@ -2579,9 +2591,11 @@ STAGE PLANS:
               key expressions: _col0 (type: int)
               sort order: +
               Statistics: Num rows: 3 Data size: 215 Basic stats: COMPLETE Column stats: NONE
-              value expressions: _col0 (type: int), _col1 (type: bigint)
+              value expressions: _col1 (type: bigint)
       Reduce Operator Tree:
-        Extract
+        Select Operator
+          expressions: KEY.reducesinkkey0 (type: int), VALUE._col0 (type: bigint)
+          outputColumnNames: _col0, _col1
           Statistics: Num rows: 3 Data size: 215 Basic stats: COMPLETE Column stats: NONE
           File Output Operator
             compressed: false

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/show_create_table_db_table.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/show_create_table_db_table.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/show_create_table_db_table.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/show_create_table_db_table.q.out Wed Aug 13 02:28:54 2014
@@ -44,8 +44,11 @@ TBLPROPERTIES (
 #### A masked pattern was here ####
 PREHOOK: query: DROP TABLE tmp_feng.tmp_showcrt
 PREHOOK: type: DROPTABLE
+PREHOOK: Input: tmp_feng@tmp_showcrt
+PREHOOK: Output: tmp_feng@tmp_showcrt
 POSTHOOK: query: DROP TABLE tmp_feng.tmp_showcrt
 POSTHOOK: type: DROPTABLE
+POSTHOOK: Input: tmp_feng@tmp_showcrt
 POSTHOOK: Output: tmp_feng@tmp_showcrt
 PREHOOK: query: DROP DATABASE tmp_feng
 PREHOOK: type: DROPDATABASE

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/show_tblproperties.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/show_tblproperties.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/show_tblproperties.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/show_tblproperties.q.out Wed Aug 13 02:28:54 2014
@@ -9,7 +9,7 @@ PREHOOK: query: show tblproperties tmpfo
 PREHOOK: type: SHOW_TBLPROPERTIES
 POSTHOOK: query: show tblproperties tmpfoo("bar")
 POSTHOOK: type: SHOW_TBLPROPERTIES
-Table tmpfoo does not have property: bar	 
+Table default.tmpfoo does not have property: bar	 
 PREHOOK: query: alter table tmpfoo set tblproperties ("bar" = "bar value")
 PREHOOK: type: ALTERTABLE_PROPERTIES
 PREHOOK: Input: default@tmpfoo

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_names.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_names.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_names.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_names.q.out Wed Aug 13 02:28:54 2014
@@ -40,8 +40,11 @@ POSTHOOK: Input: default@temp_table_name
 #### A masked pattern was here ####
 PREHOOK: query: drop table Default.TEMP_TABLE_names
 PREHOOK: type: DROPTABLE
+PREHOOK: Input: default@temp_table_names
+PREHOOK: Output: default@temp_table_names
 POSTHOOK: query: drop table Default.TEMP_TABLE_names
 POSTHOOK: type: DROPTABLE
+POSTHOOK: Input: default@temp_table_names
 POSTHOOK: Output: default@temp_table_names
 PREHOOK: query: show tables 'temp_table_names'
 PREHOOK: type: SHOWTABLES

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_precedence.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_precedence.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_precedence.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/temp_table_precedence.q.out Wed Aug 13 02:28:54 2014
@@ -176,9 +176,12 @@ POSTHOOK: Input: ttp@tab2
 PREHOOK: query: -- drop the temp table, and now we should be able to see the non-temp tab2 again
 drop table ttp.tab2
 PREHOOK: type: DROPTABLE
+PREHOOK: Input: ttp@tab2
+PREHOOK: Output: ttp@tab2
 POSTHOOK: query: -- drop the temp table, and now we should be able to see the non-temp tab2 again
 drop table ttp.tab2
 POSTHOOK: type: DROPTABLE
+POSTHOOK: Input: ttp@tab2
 POSTHOOK: Output: ttp@tab2
 PREHOOK: query: describe ttp.tab2
 PREHOOK: type: DESCTABLE

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/having.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/having.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/tez/having.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/tez/having.q.out Wed Aug 13 02:28:54 2014
@@ -1207,3 +1207,86 @@ POSTHOOK: Input: default@src
 96	val_96
 97	val_97
 98	val_98
+PREHOOK: query: EXPLAIN SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+PREHOOK: type: QUERY
+POSTHOOK: query: EXPLAIN SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+POSTHOOK: type: QUERY
+STAGE DEPENDENCIES:
+  Stage-1 is a root stage
+  Stage-0 depends on stages: Stage-1
+
+STAGE PLANS:
+  Stage: Stage-1
+    Tez
+      Edges:
+        Reducer 2 <- Map 1 (SIMPLE_EDGE)
+#### A masked pattern was here ####
+      Vertices:
+        Map 1 
+            Map Operator Tree:
+                TableScan
+                  alias: src
+                  Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                  Select Operator
+                    expressions: key (type: string), value (type: string)
+                    outputColumnNames: key, value
+                    Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                    Group By Operator
+                      aggregations: count(value)
+                      keys: key (type: string)
+                      mode: hash
+                      outputColumnNames: _col0, _col1
+                      Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                      Reduce Output Operator
+                        key expressions: _col0 (type: string)
+                        sort order: +
+                        Map-reduce partition columns: _col0 (type: string)
+                        Statistics: Num rows: 29 Data size: 5812 Basic stats: COMPLETE Column stats: NONE
+                        value expressions: _col1 (type: bigint)
+        Reducer 2 
+            Reduce Operator Tree:
+              Group By Operator
+                aggregations: count(VALUE._col0)
+                keys: KEY._col0 (type: string)
+                mode: mergepartial
+                outputColumnNames: _col0, _col1
+                Statistics: Num rows: 14 Data size: 2805 Basic stats: COMPLETE Column stats: NONE
+                Filter Operator
+                  predicate: (_col1 >= 4) (type: boolean)
+                  Statistics: Num rows: 4 Data size: 801 Basic stats: COMPLETE Column stats: NONE
+                  Select Operator
+                    expressions: _col0 (type: string), _col1 (type: bigint)
+                    outputColumnNames: _col0, _col1
+                    Statistics: Num rows: 4 Data size: 801 Basic stats: COMPLETE Column stats: NONE
+                    File Output Operator
+                      compressed: false
+                      Statistics: Num rows: 4 Data size: 801 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 key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+PREHOOK: type: QUERY
+PREHOOK: Input: default@src
+#### A masked pattern was here ####
+POSTHOOK: query: SELECT key, COUNT(value) FROM src GROUP BY key HAVING count(value) >= 4
+POSTHOOK: type: QUERY
+POSTHOOK: Input: default@src
+#### A masked pattern was here ####
+138	4
+169	4
+230	5
+277	4
+348	5
+401	5
+406	4
+468	4
+469	5
+489	4

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/mapjoin_mapjoin.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/mapjoin_mapjoin.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
Files hive/branches/cbo/ql/src/test/results/clientpositive/tez/mapjoin_mapjoin.q.out (original) and hive/branches/cbo/ql/src/test/results/clientpositive/tez/mapjoin_mapjoin.q.out Wed Aug 13 02:28:54 2014 differ

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/vector_cast_constant.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/vector_cast_constant.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/tez/vector_cast_constant.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/tez/vector_cast_constant.q.out Wed Aug 13 02:28:54 2014
@@ -141,6 +141,7 @@ STAGE PLANS:
                         Map-reduce partition columns: _col0 (type: int)
                         Statistics: Num rows: 1049 Data size: 311170 Basic stats: COMPLETE Column stats: NONE
                         value expressions: _col1 (type: struct<count:bigint,sum:double,input:int>), _col2 (type: struct<count:bigint,sum:double,input:double>), _col3 (type: struct<count:bigint,sum:decimal(12,0),input:decimal(10,0)>)
+            Execution mode: vectorized
         Reducer 2 
             Reduce Operator Tree:
               Group By Operator

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_14.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_14.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_14.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_14.q.out Wed Aug 13 02:28:54 2014
@@ -82,7 +82,7 @@ STAGE PLANS:
                   alias: alltypesorc
                   Statistics: Num rows: 1779 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
                   Filter Operator
-                    predicate: ((((ctinyint <= cbigint) and ((cint <= cdouble) or (ctimestamp2 < ctimestamp1))) and (cdouble < ctinyint)) and ((cbigint > (- 257)) or (cfloat < cint))) (type: boolean)
+                    predicate: ((((ctinyint <= cbigint) and ((cint <= cdouble) or (ctimestamp2 < ctimestamp1))) and (cdouble < ctinyint)) and ((cbigint > -257) or (cfloat < cint))) (type: boolean)
                     Statistics: Num rows: 86 Data size: 18236 Basic stats: COMPLETE Column stats: NONE
                     Select Operator
                       expressions: ctimestamp1 (type: timestamp), cfloat (type: float), cstring1 (type: string), cboolean1 (type: boolean), cdouble (type: double)
@@ -110,7 +110,7 @@ STAGE PLANS:
                 outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10
                 Statistics: Num rows: 43 Data size: 9118 Basic stats: COMPLETE Column stats: NONE
                 Select Operator
-                  expressions: _col0 (type: timestamp), _col1 (type: float), _col2 (type: string), _col3 (type: boolean), _col4 (type: double), ((- 26.28) + _col4) (type: double), (- ((- 26.28) + _col4)) (type: double), _col5 (type: double), (_col1 * (- 26.28)) (type: double), _col6 (type: float), (- _col1) (type: float), (- _col6) (type: float), ((- ((- 26.28) + _col4)) / 10.175) (type: double), _col7 (type: double), _col8 (type: bigint), (- ((- ((- 26.28) + _col4)) / 10.175)) (type: double), ((- 1.389) % _col5) (type: double), (_col1 - _col4) (type: double), _col9 (type: double), (_col9 % 10.175) (type: double), _col10 (type: double), (- (_col1 - _col4)) (type: double)
+                  expressions: _col0 (type: timestamp), _col1 (type: float), _col2 (type: string), _col3 (type: boolean), _col4 (type: double), (-26.28 + _col4) (type: double), (- (-26.28 + _col4)) (type: double), _col5 (type: double), (_col1 * -26.28) (type: double), _col6 (type: float), (- _col1) (type: float), (- _col6) (type: float), ((- (-26.28 + _col4)) / 10.175) (type: double), _col7 (type: double), _col8 (type: bigint), (- ((- (-26.28 + _col4)) / 10.175)) (type: double), (-1.389 % _col5) (type: double), (_col1 - _col4) (type: double), _col9 (type: double), (_col9 % 10.175) (type: double), _col10 (type: double), (- (_col1 - _col4)) (type: double)
                   outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12, _col13, _col14, _col15, _col16, _col17, _col18, _col19, _col20, _col21
                   Statistics: Num rows: 43 Data size: 9118 Basic stats: COMPLETE Column stats: NONE
                   Reduce Output Operator

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_15.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_15.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_15.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_15.q.out Wed Aug 13 02:28:54 2014
@@ -78,7 +78,7 @@ STAGE PLANS:
                   alias: alltypesorc
                   Statistics: Num rows: 1407 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
                   Filter Operator
-                    predicate: (((cstring2 like '%ss%') or (cstring1 like '10%')) or ((cint >= (- 75)) and ((ctinyint = csmallint) and (cdouble >= (- 3728))))) (type: boolean)
+                    predicate: (((cstring2 like '%ss%') or (cstring1 like '10%')) or ((cint >= -75) and ((ctinyint = csmallint) and (cdouble >= -3728)))) (type: boolean)
                     Statistics: Num rows: 1407 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
                     Select Operator
                       expressions: cfloat (type: float), cboolean1 (type: boolean), cdouble (type: double), cstring1 (type: string), ctinyint (type: tinyint), cint (type: int), ctimestamp1 (type: timestamp)
@@ -106,7 +106,7 @@ STAGE PLANS:
                 outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12
                 Statistics: Num rows: 703 Data size: 188484 Basic stats: COMPLETE Column stats: NONE
                 Select Operator
-                  expressions: _col0 (type: float), _col1 (type: boolean), _col2 (type: double), _col3 (type: string), _col4 (type: tinyint), _col5 (type: int), _col6 (type: timestamp), _col7 (type: double), ((- 26.28) - _col5) (type: double), _col8 (type: double), (_col2 * 79.553) (type: double), (33 % _col0) (type: float), _col9 (type: double), _col10 (type: double), ((- 23) % _col2) (type: double), (- _col4) (type: tinyint), _col11 (type: double), (_col5 - _col0) (type: float), ((- 23) % _col4) (type: int), (- ((- 26.28) - _col5)) (type: double), _col12 (type: double)
+                  expressions: _col0 (type: float), _col1 (type: boolean), _col2 (type: double), _col3 (type: string), _col4 (type: tinyint), _col5 (type: int), _col6 (type: timestamp), _col7 (type: double), (-26.28 - _col5) (type: double), _col8 (type: double), (_col2 * 79.553) (type: double), (33 % _col0) (type: float), _col9 (type: double), _col10 (type: double), (-23 % _col2) (type: double), (- _col4) (type: tinyint), _col11 (type: double), (_col5 - _col0) (type: float), (-23 % _col4) (type: int), (- (-26.28 - _col5)) (type: double), _col12 (type: double)
                   outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12, _col13, _col14, _col15, _col16, _col17, _col18, _col19, _col20
                   Statistics: Num rows: 703 Data size: 188484 Basic stats: COMPLETE Column stats: NONE
                   Reduce Output Operator

Modified: hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_9.q.out
URL: http://svn.apache.org/viewvc/hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_9.q.out?rev=1617652&r1=1617651&r2=1617652&view=diff
==============================================================================
--- hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_9.q.out (original)
+++ hive/branches/cbo/ql/src/test/results/clientpositive/tez/vectorization_9.q.out Wed Aug 13 02:28:54 2014
@@ -55,7 +55,7 @@ STAGE PLANS:
                   alias: alltypesorc
                   Statistics: Num rows: 1521 Data size: 377237 Basic stats: COMPLETE Column stats: NONE
                   Filter Operator
-                    predicate: ((cstring2 like '%b%') and ((cdouble >= (- 1.389)) or (cstring1 < 'a'))) (type: boolean)
+                    predicate: ((cstring2 like '%b%') and ((cdouble >= -1.389) or (cstring1 < 'a'))) (type: boolean)
                     Statistics: Num rows: 506 Data size: 125497 Basic stats: COMPLETE Column stats: NONE
                     Select Operator
                       expressions: cstring1 (type: string), cdouble (type: double), ctimestamp1 (type: timestamp)
@@ -83,7 +83,7 @@ STAGE PLANS:
                 outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5
                 Statistics: Num rows: 253 Data size: 62748 Basic stats: COMPLETE Column stats: NONE
                 Select Operator
-                  expressions: _col0 (type: string), _col1 (type: double), _col2 (type: timestamp), (_col1 - 9763215.5639) (type: double), (- (_col1 - 9763215.5639)) (type: double), _col3 (type: bigint), _col4 (type: double), (- _col4) (type: double), (_col4 * _col3) (type: double), _col5 (type: double), (9763215.5639 / _col1) (type: double), (_col3 / (- 1.389)) (type: double), _col4 (type: double)
+                  expressions: _col0 (type: string), _col1 (type: double), _col2 (type: timestamp), (_col1 - 9763215.5639) (type: double), (- (_col1 - 9763215.5639)) (type: double), _col3 (type: bigint), _col4 (type: double), (- _col4) (type: double), (_col4 * _col3) (type: double), _col5 (type: double), (9763215.5639 / _col1) (type: double), (_col3 / -1.389) (type: double), _col4 (type: double)
                   outputColumnNames: _col0, _col1, _col2, _col3, _col4, _col5, _col6, _col7, _col8, _col9, _col10, _col11, _col12
                   Statistics: Num rows: 253 Data size: 62748 Basic stats: COMPLETE Column stats: NONE
                   File Output Operator