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

[08/50] [abbrv] hive git commit: HIVE-18359: Extend grouping set limits from int to long (Prasanth Jayachandran reviewed by Jesus Camacho Rodriguez)

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets2.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets2.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets2.q.out
index 1877bba..d8da29a 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets2.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets2.q.out
@@ -133,18 +133,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 2:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 24 Data size: 8832 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -165,7 +165,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -175,11 +175,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 12 Data size: 4416 Basic stats: COMPLETE Column stats: NONE
@@ -314,18 +314,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 2:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 24 Data size: 8832 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -346,7 +346,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -356,11 +356,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 12 Data size: 4416 Basic stats: COMPLETE Column stats: NONE
@@ -489,18 +489,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFSumDouble(col 2:double) -> double
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 24 Data size: 13248 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -521,7 +521,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:double
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:double
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -531,11 +531,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFSumDouble(col 3:double) -> double
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 12 Data size: 6624 Basic stats: COMPLETE Column stats: NONE
@@ -718,25 +718,25 @@ STAGE PLANS:
                     aggregators: VectorUDAFSumLong(col 2:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
-                Statistics: Num rows: 12 Data size: 2184 Basic stats: COMPLETE Column stats: COMPLETE
+                Statistics: Num rows: 12 Data size: 2232 Basic stats: COMPLETE Column stats: COMPLETE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
                       native: true
                       nativeConditionsMet: hive.vectorized.execution.reducesink.new.enabled IS true, hive.execution.engine tez IN [tez, spark] IS true, No PTF TopN IS true, No DISTINCT columns IS true, BinarySortableSerDe for keys IS true, LazyBinarySerDe for values IS true
                       valueColumnNums: [3]
-                  Statistics: Num rows: 12 Data size: 2184 Basic stats: COMPLETE Column stats: COMPLETE
+                  Statistics: Num rows: 12 Data size: 2232 Basic stats: COMPLETE Column stats: COMPLETE
                   value expressions: _col3 (type: bigint)
         Reducer 3 
             Execution mode: vectorized, llap
@@ -750,7 +750,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -760,14 +760,14 @@ STAGE PLANS:
                     aggregators: VectorUDAFSumLong(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
-                Statistics: Num rows: 12 Data size: 2184 Basic stats: COMPLETE Column stats: COMPLETE
+                Statistics: Num rows: 12 Data size: 2232 Basic stats: COMPLETE Column stats: COMPLETE
                 pruneGroupingSetId: true
                 Select Operator
                   expressions: _col0 (type: string), _col1 (type: string), _col3 (type: bigint)

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3.q.out
index 7c9f668..7911611 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3.q.out
@@ -70,14 +70,14 @@ STAGE PLANS:
                     Statistics: Num rows: 12 Data size: 6624 Basic stats: COMPLETE Column stats: NONE
                     Group By Operator
                       aggregations: avg(c), count()
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3, _col4
                       Statistics: Num rows: 48 Data size: 26496 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Statistics: Num rows: 48 Data size: 26496 Basic stats: COMPLETE Column stats: NONE
                         value expressions: _col3 (type: struct<count:bigint,sum:double,input:string>), _col4 (type: bigint)
             Execution mode: llap
@@ -100,7 +100,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -110,11 +110,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgFinal(col 3:struct<count:bigint,sum:double,input:string>) -> double, VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 13248 Basic stats: COMPLETE Column stats: NONE
@@ -178,14 +178,14 @@ STAGE PLANS:
                     Statistics: Num rows: 12 Data size: 6624 Basic stats: COMPLETE Column stats: NONE
                     Group By Operator
                       aggregations: avg(c), count()
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3, _col4
                       Statistics: Num rows: 48 Data size: 26496 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Statistics: Num rows: 48 Data size: 26496 Basic stats: COMPLETE Column stats: NONE
                         value expressions: _col3 (type: struct<count:bigint,sum:double,input:string>), _col4 (type: bigint)
             Execution mode: llap
@@ -208,7 +208,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -218,11 +218,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgFinal(col 3:struct<count:bigint,sum:double,input:string>) -> double, VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 13248 Basic stats: COMPLETE Column stats: NONE
@@ -352,18 +352,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgPartial2(col 2:struct<count:bigint,sum:double,input:string>) -> struct<count:bigint,sum:double,input:string>, VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3, _col4
                 Statistics: Num rows: 48 Data size: 26496 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -384,7 +384,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:double,input:string>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -394,11 +394,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgFinal(col 3:struct<count:bigint,sum:double,input:string>) -> double, VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 13248 Basic stats: COMPLETE Column stats: NONE

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3_dec.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3_dec.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3_dec.q.out
index d98ce9b..8d2247d 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3_dec.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets3_dec.q.out
@@ -81,18 +81,18 @@ STAGE PLANS:
                           aggregators: VectorUDAFAvgDecimal(col 2:decimal(10,2)) -> struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VectorUDAFCountStar(*) -> bigint
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: [0, 1]
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3, _col4
                       Statistics: Num rows: 48 Data size: 23040 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -130,7 +130,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -140,11 +140,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgDecimalFinal(col 3:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>) -> decimal(14,6), VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 11520 Basic stats: COMPLETE Column stats: NONE
@@ -219,18 +219,18 @@ STAGE PLANS:
                           aggregators: VectorUDAFAvgDecimal(col 2:decimal(10,2)) -> struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VectorUDAFCountStar(*) -> bigint
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: [0, 1]
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3, _col4
                       Statistics: Num rows: 48 Data size: 23040 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -268,7 +268,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -278,11 +278,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgDecimalFinal(col 3:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>) -> decimal(14,6), VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 11520 Basic stats: COMPLETE Column stats: NONE
@@ -442,18 +442,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgDecimalPartial2(col 2:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>) -> struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 4:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3, _col4
                 Statistics: Num rows: 48 Data size: 23040 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -474,7 +474,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 5
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>, VALUE._col1:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -484,11 +484,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFAvgDecimalFinal(col 3:struct<count:bigint,sum:decimal(20,2),input:decimal(10,2)>) -> decimal(14,6), VectorUDAFCountMerge(col 4:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0, 1]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3, _col4
                 Statistics: Num rows: 24 Data size: 11520 Basic stats: COMPLETE Column stats: NONE

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets4.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets4.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets4.q.out
index 6a5e679..55c18fa 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets4.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets4.q.out
@@ -82,18 +82,18 @@ STAGE PLANS:
                           aggregators: VectorUDAFCountStar(*) -> bigint
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: [0]
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3
                       Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -103,9 +103,9 @@ STAGE PLANS:
                         Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                         value expressions: _col3 (type: bigint)
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -143,7 +143,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -153,11 +153,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE
@@ -219,7 +219,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -229,11 +229,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE
@@ -326,18 +326,18 @@ STAGE PLANS:
                           aggregators: VectorUDAFCountStar(*) -> bigint
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: [0]
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2, _col3
                       Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -347,9 +347,9 @@ STAGE PLANS:
                         Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                         value expressions: _col3 (type: bigint)
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -387,7 +387,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -397,11 +397,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE
@@ -463,7 +463,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -473,11 +473,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE
@@ -660,18 +660,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 2:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -681,9 +681,9 @@ STAGE PLANS:
                   Statistics: Num rows: 8 Data size: 2944 Basic stats: COMPLETE Column stats: NONE
                   value expressions: _col3 (type: bigint)
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -704,7 +704,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -714,11 +714,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE
@@ -780,7 +780,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -790,11 +790,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 4 Data size: 1472 Basic stats: COMPLETE Column stats: NONE

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets5.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets5.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets5.q.out
index 4d8fa16..4e57988 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets5.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets5.q.out
@@ -144,18 +144,18 @@ STAGE PLANS:
                       aggregators: VectorUDAFCountStar(*) -> bigint
                       className: VectorGroupByOperator
                       groupByMode: HASH
-                      keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 2:int
+                      keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 2:bigint
                       native: false
                       vectorProcessingMode: HASH
                       projectedOutputColumnNums: [0]
-                  keys: _col0 (type: string), _col1 (type: string), 0 (type: int)
+                  keys: _col0 (type: string), _col1 (type: string), 0 (type: bigint)
                   mode: hash
                   outputColumnNames: _col0, _col1, _col2, _col3
                   Statistics: Num rows: 12 Data size: 4416 Basic stats: COMPLETE Column stats: NONE
                   Reduce Output Operator
-                    key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                    key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                     sort order: +++
-                    Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                    Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                     Reduce Sink Vectorization:
                         className: VectorReduceSinkMultiKeyOperator
                         keyColumnNums: [0, 1, 2]
@@ -176,7 +176,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -186,11 +186,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 6 Data size: 2208 Basic stats: COMPLETE Column stats: NONE
@@ -336,18 +336,18 @@ STAGE PLANS:
                       aggregators: VectorUDAFCountStar(*) -> bigint
                       className: VectorGroupByOperator
                       groupByMode: HASH
-                      keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 2:int
+                      keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 2:bigint
                       native: false
                       vectorProcessingMode: HASH
                       projectedOutputColumnNums: [0]
-                  keys: _col0 (type: string), _col1 (type: string), 0 (type: int)
+                  keys: _col0 (type: string), _col1 (type: string), 0 (type: bigint)
                   mode: hash
                   outputColumnNames: _col0, _col1, _col2, _col3
                   Statistics: Num rows: 12 Data size: 4416 Basic stats: COMPLETE Column stats: NONE
                   Reduce Output Operator
-                    key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                    key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                     sort order: +++
-                    Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                    Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                     Reduce Sink Vectorization:
                         className: VectorReduceSinkMultiKeyOperator
                         keyColumnNums: [0, 1, 2]
@@ -368,7 +368,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -378,11 +378,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 6 Data size: 2208 Basic stats: COMPLETE Column stats: NONE
@@ -597,18 +597,18 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 2:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: PARTIALS
-                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:int
+                    keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 3:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), 0 (type: bigint)
                 mode: partials
                 outputColumnNames: _col0, _col1, _col2, _col3
                 Statistics: Num rows: 12 Data size: 4416 Basic stats: COMPLETE Column stats: NONE
                 Reduce Output Operator
-                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   sort order: +++
-                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                  Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                   Reduce Sink Vectorization:
                       className: VectorReduceSinkMultiKeyOperator
                       keyColumnNums: [0, 1, 2]
@@ -629,7 +629,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 4
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int, VALUE._col0:bigint
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint, VALUE._col0:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -639,11 +639,11 @@ STAGE PLANS:
                     aggregators: VectorUDAFCountMerge(col 3:bigint) -> bigint
                     className: VectorGroupByOperator
                     groupByMode: FINAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: STREAMING
                     projectedOutputColumnNums: [0]
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: final
                 outputColumnNames: _col0, _col1, _col3
                 Statistics: Num rows: 6 Data size: 2208 Basic stats: COMPLETE Column stats: NONE

http://git-wip-us.apache.org/repos/asf/hive/blob/ddd4c9ae/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets6.q.out
----------------------------------------------------------------------
diff --git a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets6.q.out b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets6.q.out
index 5e9e204..83c7ad8 100644
--- a/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets6.q.out
+++ b/ql/src/test/results/clientpositive/llap/vector_groupby_grouping_sets6.q.out
@@ -74,18 +74,18 @@ STAGE PLANS:
                       Group By Vectorization:
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: []
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2
                       Statistics: Num rows: 6 Data size: 2208 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -122,7 +122,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 3
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -130,11 +130,11 @@ STAGE PLANS:
                 Group By Vectorization:
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: []
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1
                 Statistics: Num rows: 3 Data size: 1104 Basic stats: COMPLETE Column stats: NONE
@@ -217,18 +217,18 @@ STAGE PLANS:
                       Group By Vectorization:
                           className: VectorGroupByOperator
                           groupByMode: HASH
-                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:int
+                          keyExpressions: col 0:string, col 1:string, ConstantVectorExpression(val 0) -> 5:bigint
                           native: false
                           vectorProcessingMode: HASH
                           projectedOutputColumnNums: []
-                      keys: a (type: string), b (type: string), 0 (type: int)
+                      keys: a (type: string), b (type: string), 0 (type: bigint)
                       mode: hash
                       outputColumnNames: _col0, _col1, _col2
                       Statistics: Num rows: 6 Data size: 2208 Basic stats: COMPLETE Column stats: NONE
                       Reduce Output Operator
-                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        key expressions: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         sort order: +++
-                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: int)
+                        Map-reduce partition columns: _col0 (type: string), _col1 (type: string), _col2 (type: bigint)
                         Reduce Sink Vectorization:
                             className: VectorReduceSinkMultiKeyOperator
                             keyColumnNums: [0, 1, 2]
@@ -265,7 +265,7 @@ STAGE PLANS:
                 vectorized: true
                 rowBatchContext:
                     dataColumnCount: 3
-                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:int
+                    dataColumns: KEY._col0:string, KEY._col1:string, KEY._col2:bigint
                     partitionColumnCount: 0
                     scratchColumnTypeNames: []
             Reduce Operator Tree:
@@ -273,11 +273,11 @@ STAGE PLANS:
                 Group By Vectorization:
                     className: VectorGroupByOperator
                     groupByMode: MERGEPARTIAL
-                    keyExpressions: col 0:string, col 1:string, col 2:int
+                    keyExpressions: col 0:string, col 1:string, col 2:bigint
                     native: false
                     vectorProcessingMode: MERGE_PARTIAL
                     projectedOutputColumnNums: []
-                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: int)
+                keys: KEY._col0 (type: string), KEY._col1 (type: string), KEY._col2 (type: bigint)
                 mode: mergepartial
                 outputColumnNames: _col0, _col1
                 Statistics: Num rows: 3 Data size: 1104 Basic stats: COMPLETE Column stats: NONE